2025.11.13 09:04:16.971453 [ 419 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.11.13 09:04:16.971592 [ 419 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.11.13 09:04:38.947672 [ 419 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.11.13 09:04:38.948801 [ 419 ] {} KeeperLogStore: Removing all changelogs 2025.11.13 09:04:38.950494 [ 419 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.11.13 09:04:38.963359 [ 419 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.11.13 09:04:38.963478 [ 419 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.11.13 09:04:39.015330 [ 1111 ] {} RaftInstance: Election timeout, initiate leader election 2025.11.13 09:04:39.217822 [ 419 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.11.13 09:04:39.217966 [ 419 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.11.13 09:04:39.285079 [ 419 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.11.13 09:04:39.287804 [ 419 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.11.13 09:04:59.243231 [ 424 ] {3c8080f2-fc33-4d08-b10a-8b5c391f8251} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.11.13 09:05:10.242918 [ 424 ] {12fa9bad-440d-423b-ba5e-ec0200c5f5bf} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.11.13 09:05:26.580708 [ 1115 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.11.13 09:05:29.673718 [ 1448 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.11.13 09:05:29.673901 [ 1448 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.11.13 09:05:51.338110 [ 1448 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.11.13 09:05:51.346856 [ 1448 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.11.13 09:05:51.346936 [ 1448 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.11.13 09:05:51.398110 [ 2137 ] {} RaftInstance: Election timeout, initiate leader election 2025.11.13 09:05:51.768524 [ 1448 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.11.13 09:05:51.770374 [ 1448 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.11.13 09:06:20.513623 [ 2170 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5a642d2d-8981-43c6-8ee1-d369be3bbe53::202511_1_6_1}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001f85446d 4. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000001f84c969 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:146: CurrentMemoryTracker::injectFault() @ 0x000000001f62af1f 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:269: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000001f8efcd5 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a57ca6b 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a57949e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fdea4e1fac3 18. ? @ 0x00007fdea4eb1850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:06:41.145938 [ 1453 ] {056ea29a-97f8-471a-a534-50b26826d1c3} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 5.11 GiB (attempt to allocate chunk of 2.86 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (avg_value_size_hint = 127.172607421875, avg_chars_size = 143.00712890625, limit = 8192): (while reading column URL): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 8 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41020) (query 1, line 1) (in query: INSERT INTO test.hits_s3 SELECT * FROM datasets.hits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fdea4e1fac3 2025.11.13 09:06:46.420691 [ 1453 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 5.11 GiB (attempt to allocate chunk of 2.86 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (avg_value_size_hint = 127.172607421875, avg_chars_size = 143.00712890625, limit = 8192): (while reading column URL): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 8 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fdea4e1fac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fdea4e1fac3 13. ? @ 0x00007fdea4eb1850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fdea4e1fac3 11. ? @ 0x00007fdea4eb1850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fdea4e1fac3 13. ? @ 0x00007fdea4eb1850 2025.11.13 09:06:54.328052 [ 1453 ] {826989a9-bfe5-4d73-991f-f5b22f5aa6d6} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 5.04 GiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column RefererCategories): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 76 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43366) (query 1, line 1) (in query: INSERT INTO test.hits SELECT * FROM datasets.hits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:141: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5afa72 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fdea4e1fac3 2025.11.13 09:06:57.246679 [ 1453 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 5.04 GiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column RefererCategories): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 76 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:141: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5afa72 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fdea4e1fac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fdea4e1fac3 11. ? @ 0x00007fdea4eb1850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fdea4e1fac3 13. ? @ 0x00007fdea4eb1850 2025.11.13 09:07:35.399071 [ 1453 ] {5ee6d288-39d6-49dc-8522-875f73a0cb3f} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 4.44 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column ClickGroupBannerID): (while reading from part store/513/5131f834-711f-4168-98a5-968b691a104b/201403_1_8_2/ in table datasets.visits_v1 (5131f834-711f-4168-98a5-968b691a104b) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 76 with max_rows_to_read = 7411): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35960) (query 1, line 1) (in query: INSERT INTO test.visits SELECT * FROM datasets.visits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7ac08c 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fdea4e1fac3 31. ? @ 0x00007fdea4eb1850 2025.11.13 09:07:39.244126 [ 1453 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 4.44 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column ClickGroupBannerID): (while reading from part store/513/5131f834-711f-4168-98a5-968b691a104b/201403_1_8_2/ in table datasets.visits_v1 (5131f834-711f-4168-98a5-968b691a104b) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 76 with max_rows_to_read = 7411): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7ac08c 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 18. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fdea4e1fac3 31. ? @ 0x00007fdea4eb1850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fdea4e1fac3 11. ? @ 0x00007fdea4eb1850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fdea4e1fac3 13. ? @ 0x00007fdea4eb1850 2025.11.13 09:07:51.446439 [ 2140 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.11.13 09:07:54.314026 [ 2992 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.11.13 09:07:54.314162 [ 2992 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.11.13 09:08:20.248747 [ 2992 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.11.13 09:08:20.259195 [ 2992 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.11.13 09:08:20.259277 [ 2992 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.11.13 09:08:20.310529 [ 3698 ] {} RaftInstance: Election timeout, initiate leader election 2025.11.13 09:08:20.722245 [ 2992 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.11.13 09:08:20.731673 [ 2992 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.11.13 09:08:20.734466 [ 2992 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.11.13 09:08:46.299905 [ 2997 ] {24479f0d-55ef-4114-b0f0-065c4c9545d8} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(UInt8))): In scope SELECT formatRow('RawBLOB', [[[33]], []]). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48422) (comment: 02423_multidimensional_array_get_data_at.sql) (query 1, line 1) (in query: SELECT formatRow('RawBLOB', [[[33]], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.301621 [ 2997 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(UInt8))): In scope SELECT formatRow('RawBLOB', [[[33]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.312677 [ 2997 ] {cf8ff1a9-dc46-4721-8c3e-ddbe2e1be746} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Nothing))): In scope SELECT formatRow('RawBLOB', [[[]], []]). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48422) (comment: 02423_multidimensional_array_get_data_at.sql) (query 2, line 2) (in query: SELECT formatRow('RawBLOB', [[[]], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.313624 [ 2997 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Nothing))): In scope SELECT formatRow('RawBLOB', [[[]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.324858 [ 2997 ] {1571c0e0-3b32-43c9-aa5f-193f05721c5f} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Array(Array(Array(Array(UInt8))))))): In scope SELECT formatRow('RawBLOB', [[[[[[[72, 101, 108, 108, 111]]]]]], []]). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48422) (comment: 02423_multidimensional_array_get_data_at.sql) (query 3, line 3) (in query: SELECT formatRow('RawBLOB', [[[[[[[0x48, 0x65, 0x6c, 0x6c, 0x6f]]]]]], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.325740 [ 2997 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Array(Array(Array(Array(UInt8))))))): In scope SELECT formatRow('RawBLOB', [[[[[[[72, 101, 108, 108, 111]]]]]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.336408 [ 2997 ] {df09cecc-50ba-4fef-a02b-cb4a1c773805} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Nothing)): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(Array(Nothing))')). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48422) (comment: 02423_multidimensional_array_get_data_at.sql) (query 4, line 4) (in query: SELECT formatRow('RawBLOB', []::Array(Array(Nothing)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.337282 [ 2997 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Nothing)): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(Array(Nothing))')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.345909 [ 2997 ] {bb176926-96fe-4f13-b89d-342945eb59e3} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[], [['Hello']]]). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48422) (comment: 02423_multidimensional_array_get_data_at.sql) (query 5, line 5) (in query: SELECT formatRow('RawBLOB', [[], [['Hello']]]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.346779 [ 2997 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[], [['Hello']]]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.355215 [ 2997 ] {9bb27138-3091-4864-90a3-843460f7d613} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[['World']], []]). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48422) (comment: 02423_multidimensional_array_get_data_at.sql) (query 6, line 6) (in query: SELECT formatRow('RawBLOB', [[['World']], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.356035 [ 2997 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[['World']], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.366628 [ 2997 ] {b1c2ac7a-984c-4af1-b9a1-6d14643478a0} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(String): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(String)')). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48422) (comment: 02423_multidimensional_array_get_data_at.sql) (query 7, line 7) (in query: SELECT formatRow('RawBLOB', []::Array(String));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:46.367829 [ 2997 ] {} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(String): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(String)')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000003709ba11 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000003b9ca35d 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000003b22b395 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee6c61f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:08:48.381747 [ 4028 ] {f0d0185e-6696-49df-8e52-87b7846bb37c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48502) (comment: 03202_dynamic_null_map_subcolumn.gen.sql) (query 11, line 17) (in query: insert into test select number, arrayMap(x -> multiIf(number % 9 == 0, NULL, number % 9 == 3, 'str_' || toString(number), number), range(number % 10 + 1)) from numbers(20, 10) settings min_insert_block_size_rows=50000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:08:48.712709 [ 4221 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:08:49.053334 [ 4028 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:08:49.321654 [ 4221 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:08:49.416576 [ 4017 ] {e042b3d2-0fb2-430e-9ca4-bbc02bce67f6} executeQuery: Code: 60. DB::Exception: Table test_5.buf_00097 does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48540) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (query 2, line 1) (in query: DROP TABLE buf_00097;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:08:49.416576 [ 4389 ] {b57036af-f487-4f45-b1c7-0f58381aad3c} executeQuery: Code: 60. DB::Exception: Table test_5.buf_00097 does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48548) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (query 2, line 1) (in query: DROP TABLE buf_00097;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:08:49.418627 [ 4017 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.buf_00097 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:08:49.420253 [ 4389 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.buf_00097 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:08:50.580538 [ 3724 ] {0c622046-10d2-45e1-a881-77a913a60e91::2_2_2_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:08:51.139859 [ 4607 ] {5530510a-f23d-46b8-86da-1f87ce43015f} executeQuery: Code: 520. DB::Exception: Cannot drop/detach dictionary test_1.02181_test_dictionary as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48652) (comment: 02181_dictionary_attach_detach.sql) (query 6, line 22) (in query: DETACH TABLE 02181_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:162: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x00000000384411d4 5. ./build_docker/./src/Storages/StorageDictionary.cpp:175: DB::StorageDictionary::checkTableCanBeDetached() const @ 0x000000003844133a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a699f0 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:08:51.141745 [ 4607 ] {} TCPHandler: Code: 520. DB::Exception: Cannot drop/detach dictionary test_1.02181_test_dictionary as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:162: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x00000000384411d4 5. ./build_docker/./src/Storages/StorageDictionary.cpp:175: DB::StorageDictionary::checkTableCanBeDetached() const @ 0x000000003844133a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a699f0 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:08:51.199894 [ 4529 ] {133a3d47-7d35-492c-8444-2cbcdffca25f} executeQuery: Code: 60. DB::Exception: Table test_5.buf_00097 does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (in query: /* ddl_entry=query-0000000007 */ DROP TABLE test_5.buf_00097 SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:08:51.207534 [ 4529 ] {133a3d47-7d35-492c-8444-2cbcdffca25f} executeQuery: Code: 60. DB::Exception: Table test_5.buf_00097 does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48566) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (query 2, line 1) (in query: DROP TABLE buf_00097;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:08:51.212818 [ 4529 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.buf_00097 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 18. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 19. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:08:51.414529 [ 4550 ] {f26f7f3d-1d8b-4274-ae83-308c8a91da95} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52384) (comment: 02867_null_lc_in_bug.sql) (in query: DROP DATABASE IF EXISTS test_ln6i37yf SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:08:51.416723 [ 4550 ] {f26f7f3d-1d8b-4274-ae83-308c8a91da95} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:08:51.623302 [ 3724 ] {0c622046-10d2-45e1-a881-77a913a60e91::2_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:230: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032eb6bd6 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000003a0a6ec1 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000003a0a4916 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:08:51.623988 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0c622046-10d2-45e1-a881-77a913a60e91::2_2_2_0_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:230: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032eb6bd6 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000003a0a6ec1 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000003a0a4916 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:08:51.741954 [ 4221 ] {34c79c38-946b-452c-a8a1-8a0df33246cf} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '2_2_2_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 . (UNFINISHED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48644) (comment: 03221_mutation_analyzer_skip_part.sh) (query 6, line 12) (in query: ALTER TABLE t_mutate_skip_part UPDATE v1 = 1000 WHERE key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:08:51.752832 [ 4221 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '2_2_2_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:08:51.908557 [ 4607 ] {10c40c84-010e-4e97-bc8d-3c4a04a475e2} executeQuery: Code: 80. DB::Exception: Cannot ATTACH TABLE test_1.`02181_test_dictionary`, it is a Dictionary. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48652) (comment: 02181_dictionary_attach_detach.sql) (query 7, line 23) (in query: ATTACH TABLE 02181_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1564: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000032a01624 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:08:51.910490 [ 4607 ] {} TCPHandler: Code: 80. DB::Exception: Cannot ATTACH TABLE test_1.`02181_test_dictionary`, it is a Dictionary. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1564: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000032a01624 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:08:53.482224 [ 4607 ] {aa7b2075-c1c1-4722-932f-2bddd3a9313d} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48652) (comment: 02181_dictionary_attach_detach.sql) (query 16, line 38) (in query: DROP DICTIONARY 02181_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:08:53.483788 [ 4607 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:08:53.892523 [ 4528 ] {5a7bfdb3-cc95-4c38-8908-2468287c211a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (in query: /* ddl_entry=query-0000000011 */ TRUNCATE TABLE test_5.buf_00097), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:08:53.897696 [ 4528 ] {5a7bfdb3-cc95-4c38-8908-2468287c211a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48558) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (query 6, line 3) (in query: DROP TABLE buf_00097;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:08:53.901232 [ 4528 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:08:54.949576 [ 4529 ] {24e4d311-6d77-4bcc-99ab-338b336ac510} executeQuery: Code: 57. DB::Exception: Table test_15.partitioned_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42198) (comment: 03008_deduplication_insert_into_partitioned_table.sql) (query 17, line 36) (in query: CREATE TABLE partitioned_table (`key` Int64, `value` String) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/03008_deduplication_insert_into_partitioned_table', '{replica}') PARTITION BY key % 10 ORDER BY tuple() SETTINGS index_granularity = 63695, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.5024712681770325, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 64490541, compact_parts_max_bytes_to_buffer = 125430481, compact_parts_max_granules_to_buffer = 254, compact_parts_merge_max_bytes_to_prefetch_part = 24189813, merge_max_block_size = 12052, old_parts_lifetime = 11., prefer_fetch_merged_part_size_threshold = 9878856224, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10253571475, index_granularity_bytes = 11143355, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 41, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 89777, primary_key_compress_block_size = 51897, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:08:54.955382 [ 4529 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.partitioned_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:08:54.960605 [ 4936 ] {c295c962-3c4e-4d80-97b2-df1e41c178f2} executeQuery: Code: 183. DB::Exception: arrayJoin is not allowed in mutations. (UNEXPECTED_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02504_disallow_arrayjoin_in_mutations.sql) (in query: /* ddl_entry=query-0000000003 */ ALTER TABLE test_ur65r400.test_02504 (UPDATE b = 33 WHERE arrayJoin([1, 2]) = a)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1381: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000032ef0ebd 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1467: DB::MutationsInterpreter::validate() @ 0x0000000032efabe2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991c01 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:08:54.966954 [ 4936 ] {c295c962-3c4e-4d80-97b2-df1e41c178f2} executeQuery: Code: 183. DB::Exception: arrayJoin is not allowed in mutations. (UNEXPECTED_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42252) (comment: 02504_disallow_arrayjoin_in_mutations.sql) (query 5, line 7) (in query: ALTER TABLE test_02504 UPDATE b = 33 WHERE arrayJoin([1, 2]) = a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1381: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000032ef0ebd 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1467: DB::MutationsInterpreter::validate() @ 0x0000000032efabe2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991c01 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:08:54.969006 [ 4936 ] {} TCPHandler: Code: 183. DB::Exception: arrayJoin is not allowed in mutations. (UNEXPECTED_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1381: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000032ef0ebd 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1467: DB::MutationsInterpreter::validate() @ 0x0000000032efabe2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991c01 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:08:56.710033 [ 4529 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database no_such_database_could_exist does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:539: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x0000000031ae3afe 5. ./build_docker/./src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x000000003aea11be 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:08:56.710353 [ 4529 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database no_such_database_could_exist does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:539: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x0000000031ae3afe 5. ./build_docker/./src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x000000003aea11be 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:08:57.706335 [ 4964 ] {9d832810-ef03-4756-a037-2d442884a32b} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42400) (comment: 02268_json_wrong_root_type_in_schema_inference.sql) (query 2, line 4) (in query: select * from file('02268_data.jsonl');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a3f964d 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ee8e9 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:08:57.708010 [ 4964 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '{' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a3f964d 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ee8e9 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:08:57.762115 [ 4964 ] {f00b78dd-6514-4182-b4dc-b6f60bbf582f} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '[' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonCompactEachRow). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42400) (comment: 02268_json_wrong_root_type_in_schema_inference.sql) (query 4, line 7) (in query: select * from file('02268_data.jsonCompactEachRow');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a3f964d 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ee8e9 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:08:57.763777 [ 4964 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONCompactEachRow format file. Error: Code: 27. DB::Exception: Cannot parse input: expected '[' before: '1\n'. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02268_data.jsonCompactEachRow). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a3f964d 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ee8e9 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:08:58.918924 [ 4528 ] {345d4a67-2556-40e1-90e8-34c5cb93102b} executeQuery: Code: 44. DB::Exception: Second argument for function toFixedString must be constant: In scope toFixedString('\n{"a": "Hello", "b": 111}\n{"a": "World", "b": 123}\n{"a": "Hello", "b": 111}\n{"a": "World", "b": 123}\n', materialize(101)). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42456) (comment: 03311_constantnode.sql) (query 5, line 5) (in query: DESCRIBE TABLE format(((toLowCardinality(0) OR NULL) OR inf OR 2) OR greatCircleAngle(materialize(0), 45, 1, 45) OR greatCircleAngle(toNullable(toUInt256(0)), 45, 1, 45) OR 0, JSONEachRow, toFixedString('\n{"a": "Hello", "b": 111}\n{"a": "World", "b": 123}\n{"a": "Hello", "b": 111}\n{"a": "World", "b": 123}\n', materialize(101)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ab202a5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:255: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030428d05 12. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000337b20eb 13. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000337b75b3 14. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000337b7ba5 15. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000337b7f03 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000268101af 17. ./build_docker/./src/TableFunctions/TableFunctionFactory.cpp:53: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002d1a11fb 18. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:157: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000339705fc 19. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:08:58.922965 [ 4528 ] {} TCPHandler: Code: 44. DB::Exception: Second argument for function toFixedString must be constant: In scope toFixedString('\n{"a": "Hello", "b": 111}\n{"a": "World", "b": 123}\n{"a": "Hello", "b": 111}\n{"a": "World", "b": 123}\n', materialize(101)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ab202a5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:255: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000030428d05 12. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000337b20eb 13. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000337b75b3 14. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000337b7ba5 15. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000337b7f03 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000268101af 17. ./build_docker/./src/TableFunctions/TableFunctionFactory.cpp:53: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002d1a11fb 18. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:157: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000339705fc 19. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:08:59.289765 [ 4936 ] {91f6cedd-5332-4d34-9004-f5a45b8c79cf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52694) (comment: 02880_indexHint__partition_id.sql) (in query: DROP DATABASE IF EXISTS test_ugfjt418 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:08:59.294583 [ 4936 ] {91f6cedd-5332-4d34-9004-f5a45b8c79cf} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:00.061065 [ 4528 ] {b4028924-6486-4d81-8659-bb0892c58f46} executeQuery: Code: 456. DB::Exception: Substitution `s` is not set. (UNKNOWN_QUERY_PARAMETER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42544) (comment: 00954_client_prepared_statements.sh) (query 1, line 1) (in query: SELECT {s:String}), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:71: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x00000000337e96fc 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:80: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000337e52ee 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:39: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e471a 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 11. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 13. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1042: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033827278 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:09:00.075112 [ 4528 ] {} TCPHandler: Code: 456. DB::Exception: Substitution `s` is not set. (UNKNOWN_QUERY_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:71: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x00000000337e96fc 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:80: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000337e52ee 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:39: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e471a 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 11. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 13. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1042: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033827278 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:09:01.008729 [ 4389 ] {184c53b4-7433-49c7-b527-774ca061213f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55222) (comment: 01560_optimize_on_insert_long.sql) (query 5, line 7) (in query: SELECT * FROM replacing_merge_tree ORDER BY key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:09:01.340537 [ 5196 ] {81d0bfb7-f225-460e-9216-9a9db4290220} executeQuery: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42622) (comment: 02025_storage_filelog_virtual_col.sh) (query 1, line 1) (in query: detach table file_log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d91d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:01.349731 [ 5196 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d91d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:01.621656 [ 4389 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:01.667192 [ 4529 ] {87af59df-de14-415f-b377-c1703f042bd3} executeQuery: Code: 36. DB::Exception: Second argument of aggregate function analysisOfVariance should be a native unsigned integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42572) (comment: 02475_analysis_of_variance.sql) (query 4, line 5) (in query: SELECT analysisOfVariance(1.11, -20);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:111: DB::(anonymous namespace)::createAggregateFunctionAnalysisOfVariance(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000263e58b7 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:09:01.669757 [ 4529 ] {} TCPHandler: Code: 36. DB::Exception: Second argument of aggregate function analysisOfVariance should be a native unsigned integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:111: DB::(anonymous namespace)::createAggregateFunctionAnalysisOfVariance(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000263e58b7 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:09:01.682250 [ 4529 ] {b7043742-d224-4f1e-9dcd-25f513558db9} executeQuery: Code: 36. DB::Exception: Second argument of aggregate function analysisOfVariance should be a native unsigned integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42572) (comment: 02475_analysis_of_variance.sql) (query 5, line 6) (in query: SELECT analysisOfVariance(1.11, 20 :: UInt128);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:111: DB::(anonymous namespace)::createAggregateFunctionAnalysisOfVariance(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000263e58b7 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:09:01.684456 [ 4529 ] {} TCPHandler: Code: 36. DB::Exception: Second argument of aggregate function analysisOfVariance should be a native unsigned integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:111: DB::(anonymous namespace)::createAggregateFunctionAnalysisOfVariance(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000263e58b7 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:09:01.732747 [ 5295 ] {872321e5-63da-4e6f-afc6-c410b34c926c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55214) (query 1, line 1) (in query: SELECT throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:01.737873 [ 5295 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.132317 [ 4528 ] {8fd7bf70-8183-4a4d-a47c-e7249ff9972b} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55232) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 2, line 2) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, ALL, a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.174890 [ 4528 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.187044 [ 4528 ] {37c32775-4db7-4eb2-8408-5e25649a0b40} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55232) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 3, line 8) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, INNER, a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.189195 [ 4528 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.201310 [ 4528 ] {b9d8d1e0-d908-40e6-9166-844243e43ede} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55232) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 4, line 14) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(SEMI, FULL, a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.203237 [ 4528 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.214007 [ 4528 ] {385e7fe1-a91e-48b3-80df-2496c0c4247f} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55232) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 5, line 20) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, ALL, a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.215815 [ 4528 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.225728 [ 4528 ] {9714dd5b-0bce-400c-97f1-7aa4048ef024} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55232) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 6, line 26) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, INNER, a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.227518 [ 4528 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.237359 [ 4528 ] {a7f1f990-5d0b-4bf8-a306-ce4dfb13f65b} executeQuery: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55232) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 7, line 32) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANTI, FULL, a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.239245 [ 4528 ] {} TCPHandler: Code: 36. DB::Exception: SEMI|ANTI JOIN should be LEFT or RIGHT. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:484: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eac11 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.759877 [ 4529 ] {f189e423-c404-4c1f-96d3-8dbba04eeef4} executeQuery: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 9000000000000001): While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42572) (comment: 02475_analysis_of_variance.sql) (query 6, line 7) (in query: SELECT analysisOfVariance(1.11, 9000000000000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000008c4592d 4. ./src/AggregateFunctions/Moments.h:452: DB::AnalysisOfVarianceMoments::resizeIfNeeded(unsigned long) @ 0x00000000263edfbc 5. ./src/AggregateFunctions/Moments.h:466: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x00000000263ed8e4 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:59: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000263ea70a 7. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000031cae26d 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb43a8 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:02.997933 [ 4887 ] {aa147931-567c-43f4-822f-ec47ab5ae2f7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55296) (query 1, line 1) (in query: SELECT throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:03.000950 [ 4887 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:03.088397 [ 4528 ] {4186199e-30ae-4bb1-96e9-f2ebcc3341d9} executeQuery: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55232) (comment: 03197_storage_join_strictness_type_restriction.sql) (query 8, line 38) (in query: CREATE TABLE t1 ( a Int64, b Int64 ) Engine = Join(ANY, FULL, a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:478: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eaf63 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:03.090706 [ 4528 ] {} TCPHandler: Code: 48. DB::Exception: ANY FULL JOINs are not implemented. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:478: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000385eaf63 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:03.104248 [ 4529 ] {} TCPHandler: Code: 36. DB::Exception: Too many groups for analysis of variance (should be no more than 1048576, got 9000000000000001): While executing AggregatingTransform. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000008c4592d 4. ./src/AggregateFunctions/Moments.h:452: DB::AnalysisOfVarianceMoments::resizeIfNeeded(unsigned long) @ 0x00000000263edfbc 5. ./src/AggregateFunctions/Moments.h:466: DB::AnalysisOfVarianceMoments::add(double, unsigned long) @ 0x00000000263ed8e4 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionAnalysisOfVariance.cpp:59: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000263ea70a 7. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000031cae26d 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb43a8 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:04.813877 [ 3732 ] {c684ce1d-3aae-4334-b210-0cec7555c7b1::all_1_1_1_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:04.814884 [ 4936 ] {1a42064f-43c5-48ad-b7d0-fd7c3a09777f} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_1' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 . (UNFINISHED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55346) (comment: 03275_block_number_mutation.sql) (query 6, line 9) (in query: ALTER TABLE t_block_number_delete DELETE WHERE x < 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:04.817655 [ 4936 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_1' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:05.348078 [ 3732 ] {c684ce1d-3aae-4334-b210-0cec7555c7b1::all_1_1_1_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:230: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032eb6bd6 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000003a0a6ec1 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000003a0a4916 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:05.396289 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c684ce1d-3aae-4334-b210-0cec7555c7b1::all_1_1_1_2}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:230: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032eb6bd6 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000003a0a6ec1 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000003a0a4916 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:09.848984 [ 6079 ] {ce22e0e7-a59d-45fd-b73e-5f4ccd6e60d4} registerStorageMergeTree: It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.11.13 09:09:10.126145 [ 6005 ] {d2f8cfea-ba02-4843-91ee-b369a2748015} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00 million, current rows: 111.22 billion. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56590) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 111222333444 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003c45b5f5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c457ec2 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c453ed4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:10.129164 [ 6005 ] {d2f8cfea-ba02-4843-91ee-b369a2748015} DynamicQueryHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00 million, current rows: 111.22 billion. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003c45b5f5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c457ec2 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c453ed4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:10.530611 [ 6079 ] {f4c573c7-df0a-4957-8696-cc0dc611c5c1} registerStorageMergeTree: It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.11.13 09:09:11.176817 [ 6092 ] {132d4d57-9791-4df8-93e4-ceccb7a05705} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56624) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:11.182010 [ 6092 ] {132d4d57-9791-4df8-93e4-ceccb7a05705} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:11.258994 [ 5639 ] {8afc85c2-925c-49e9-96b5-02c7df34fe39} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54408) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:11.260938 [ 5639 ] {8afc85c2-925c-49e9-96b5-02c7df34fe39} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1000.00 B, current bytes: 1001.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:11.429540 [ 6006 ] {5e71d4e0-d594-42b8-a5d1-7eb83146be68} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55740) (comment: 03049_unknown_identifier_materialized_column.sql) (query 10, line 14) (in query: DROP DATABASE IF EXISTS test_3i8m7z98), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:11.433577 [ 6006 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:11.637234 [ 6092 ] {8ff757f0-7a10-4776-8038-b2b3b3d3c644} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54418) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1048577 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:11.640110 [ 6092 ] {8ff757f0-7a10-4776-8038-b2b3b3d3c644} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:12.636039 [ 5295 ] {8baa87af-f6db-4b7f-843f-d30427353a64} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54422) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1048577 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:12.639210 [ 5295 ] {8baa87af-f6db-4b7f-843f-d30427353a64} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 MiB, current bytes: 1.00 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:13.206110 [ 6092 ] {9f86c9a9-6a66-4cc9-9bd9-bd21d7ca22f9} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54444) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:13.209988 [ 6092 ] {9f86c9a9-6a66-4cc9-9bd9-bd21d7ca22f9} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:13.527896 [ 4964 ] {b1cbb6a0-df9b-4ae1-9fd6-fa04d1dcaefb} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:218: DB::ConcurrentHashJoin::~ConcurrentHashJoin() @ 0x00000000327fdc8f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:67: std::__shared_ptr_emplace>::__on_zero_shared() @ 0x0000000031c24160 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:156: DB::JoinStep::~JoinStep() @ 0x000000003c17e758 9. ./src/Processors/QueryPlan/JoinStep.h:14: DB::JoinStep::~JoinStep() @ 0x000000003c17e7ee 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:80: std::__list_imp>::__delete_node[abi:ne190107](std::__list_node*) @ 0x000000003c22297d 11. ./contrib/llvm-project/libcxx/include/list:631: DB::QueryPlan::~QueryPlan() @ 0x000000003c1f4429 12. ./src/Planner/Planner.h:20: DB::Planner::~Planner() @ 0x0000000031c8f56e 13. ./src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::~InterpreterSelectQueryAnalyzer() @ 0x0000000031c8da86 14. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:143: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x000000003396f5b2 15. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:100: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cb64 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:13.806887 [ 4221 ] {92688ae9-212a-44e1-ae73-adba52bd655c} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54456) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 1500001 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:13.811071 [ 4221 ] {92688ae9-212a-44e1-ae73-adba52bd655c} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.43 MiB, current bytes: 1.43 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:14.731052 [ 4964 ] {3fece99b-1f10-42f4-b49e-8b710da2a634} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1409: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c86c7c 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 12. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 13. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:230: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x0000000032bdd873 15. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:143: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x000000003396e54d 16. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:100: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cb64 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:14.836542 [ 4964 ] {3fece99b-1f10-42f4-b49e-8b710da2a634} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42614) (comment: 02378_analyzer_projection_names.sql) (query 213, line 451) (in query: DESCRIBE (SELECT test_table_join_1.* APPLY toString, test_table_join_2.* APPLY toString FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 ON t1.id = t2.id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1409: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c86c7c 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 12. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 13. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:230: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x0000000032bdd873 15. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:143: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x000000003396e54d 16. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:100: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cb64 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:09:14.840621 [ 4964 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1409: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c86c7c 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 12. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 13. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:230: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x0000000032bdd873 15. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:143: DB::InterpreterDescribeQuery::fillColumnsFromSubquery(DB::ASTTableExpression const&) @ 0x000000003396e54d 16. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:100: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cb64 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:09:15.180084 [ 4529 ] {23ef5b51-62f6-4608-a8b6-5d15722b085e} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54472) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:15.183357 [ 4529 ] {23ef5b51-62f6-4608-a8b6-5d15722b085e} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:15.380034 [ 5803 ] {d971e9e4-a971-41fc-b7b0-f5b8909496bd} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128ReferenceKeyed((0, 0), '1'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55340) (comment: 02552_siphash128_reference.sql) (query 129, line 203) (in query: select sipHash128ReferenceKeyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e376b 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000954caaa 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000954c232 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:09:15.382753 [ 5803 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128ReferenceKeyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e376b 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000954caaa 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000954c232 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:09:15.504612 [ 4529 ] {fb7ac693-855f-455d-9952-0604261b5f62} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42700) (comment: 01675_data_type_coroutine.sh) (query 1, line 1) (in query: SELECT * FROM remote('127.0.0.{1,2}', generateRandom('x Array(Array(Array(Array(Array(Array(Array(UInt8)))))))', 1, 1, 1)) LIMIT 1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:09:15.510313 [ 4529 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:16.631758 [ 4221 ] {73642831-1b32-4742-9e95-90c5ed254299} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54480) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:16.640263 [ 4221 ] {73642831-1b32-4742-9e95-90c5ed254299} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:16.817980 [ 5295 ] {32eb736e-91cc-42c0-a2bb-76b4e336f50f} executeQuery: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42644) (comment: 02812_pointwise_array_operations.sql) (query 14, line 14) (in query: SELECT ([12,13] % [5,6]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001599730a 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000014f47c39 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:09:16.820344 [ 5295 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001599730a 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000014f47c39 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:09:17.121211 [ 6079 ] {3158ce61-c487-4486-ab5b-6441cec3a2f0} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42688) (comment: 01660_join_or_any.sql) (query 16, line 23) (in query: select a2, b2 from tab2 any left join tab3 on a2 = a3 or b2 = b3 ORDER BY a2, b2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cecf2f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1409: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c86c7c 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x0000000032bddb86 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bddfe8 12. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:717: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000003703f83e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1063: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c6a069 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:09:17.125639 [ 6079 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cecf2f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1409: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c86c7c 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x0000000032bddb86 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bddfe8 12. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:717: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000003703f83e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1063: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c6a069 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:09:17.167898 [ 5803 ] {58624b44-9e2b-4fb2-a370-1cd063f9be39} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55340) (comment: 02552_siphash128_reference.sql) (query 130, line 204) (in query: select sipHash128ReferenceKeyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e353e 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000954caaa 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000954c232 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:09:17.169847 [ 5803 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e353e 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000954caaa 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000954c232 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:09:17.852030 [ 6023 ] {7bcce9d8-d75c-4ea7-9da3-40bd49807866} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54530) (comment: 00429_long_http_bufferization.sh) (in query: SELECT greatest(toUInt8(1), toUInt8(intHash64(number))) FROM system.numbers LIMIT 5000000 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:17.854824 [ 6023 ] {7bcce9d8-d75c-4ea7-9da3-40bd49807866} DynamicQueryHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 3.81 MiB, current bytes: 3.82 MiB. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x000000002f2f6d77 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f2988 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x000000003bb4c33f 7. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 8. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 15. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 16. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 17. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:18.212824 [ 6019 ] {07f617b3-5be0-4455-98de-41aa068eeeb8} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03241_view_block_structure.sql) (in query: /* ddl_entry=query-0000000008 */ TRUNCATE TABLE test_rmkvcbxd.vfoo), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:09:18.221402 [ 6019 ] {07f617b3-5be0-4455-98de-41aa068eeeb8} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42740) (comment: 03241_view_block_structure.sql) (query 11, line 25) (in query: DROP TABLE vfoo;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:09:18.233574 [ 6019 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:09:18.276284 [ 3732 ] {205b8dc2-7b75-4374-9596-7f359671c6d7::202511_1_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:18.277493 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {205b8dc2-7b75-4374-9596-7f359671c6d7::202511_1_6_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:19.014435 [ 5295 ] {ea6bfb16-4f7f-4a60-8c84-d1a5ac327724} executeQuery: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42644) (comment: 02812_pointwise_array_operations.sql) (query 15, line 15) (in query: SELECT ([2,3,4]-[1,-2,10,29]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b352d7 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000014b2b5bc 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b231f8 7. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b1f40d 8. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b3411a 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000014b2b5bc 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b231f8 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b1f40d 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:09:19.016553 [ 5295 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b352d7 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000014b2b5bc 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b231f8 7. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b1f40d 8. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b3411a 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000014b2b5bc 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b231f8 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b1f40d 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:09:19.187769 [ 3287 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1403: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000031b06d66 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1425: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000031b07f49 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:219: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031b2b7df 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:20.541587 [ 3356 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1403: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000031b06d66 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1425: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000031b07f49 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:219: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031b2b7df 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:20.654220 [ 6028 ] {abfaa32f-bdbe-4cca-a918-cc8c039edf0f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46332) (comment: 01675_data_type_coroutine.sh) (query 1, line 1) (in query: SELECT * FROM remote('127.0.0.{1,2}', generateRandom('x Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(Array(UInt8))))))))))))', 1, 1, 1)) LIMIT 1 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:09:20.659150 [ 6028 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:21.219251 [ 5295 ] {21b6cfbf-9b49-4799-b9f5-250f35fa19e8} executeQuery: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42644) (comment: 02812_pointwise_array_operations.sql) (query 18, line 18) (in query: SELECT x, y, x+y FROM a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018828477 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001881ff5c 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001881846b 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:09:21.222238 [ 5295 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018828477 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001881ff5c 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001881846b 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:21.605395 [ 6019 ] {3be2ebfa-8007-4dfe-9aba-4d61b3534d2f} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 21, line 27) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19fc60 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:21.608766 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19fc60 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:21.861968 [ 5927 ] {a0820e9d-f9b3-4f5a-886b-894f8bc85a8b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55756) (comment: 01010_partial_merge_join.sql) (query 126, line 143) (in query: SELECT t1.*, t2.x FROM t1 ANY INNER JOIN t2 USING (x) ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:09:21.879745 [ 5927 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:22.188446 [ 6027 ] {6224b799-e075-4e16-8447-5a523ce63080} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT clamp(number, number - 1, number + 1) FROM numbers(3). (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42846) (comment: 03036_clamp.sql) (query 13, line 13) (in query: select clamp(number, number-1, number+1) from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002f546dc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002f545402 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5508b6 6. DB::FunctionClamp::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000d1085f0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:09:22.190730 [ 6027 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT clamp(number, number - 1, number + 1) FROM numbers(3). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x000000002f546dc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x000000002f545402 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5508b6 6. DB::FunctionClamp::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000d1085f0 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:09:22.309561 [ 6019 ] {52c7278e-1817-43c9-9bc4-dcdcacf87937} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 22, line 28) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:22.312097 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:22.340617 [ 6019 ] {b797408a-3860-4eab-9ea3-12be07aa2442} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 23, line 29) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:22.342881 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:22.510175 [ 6023 ] {685fc315-cba2-4215-ae76-bbd45bcd5e9d} executeQuery: Code: 6. DB::Exception: Cannot parse string 'inter' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42852) (comment: 02233_interpolate_1.sql) (query 5, line 21) (in query: # Test INTERPOLATE with incompatible const - should produce error SELECT n, source, inter FROM ( SELECT toFloat32(number % 10) AS n, 'original' AS source, number as inter FROM numbers(10) WHERE number % 3 = 1 ) ORDER BY n WITH FILL FROM 0 TO 11.51 STEP 0.5 INTERPOLATE (inter AS 'inter');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002ca5118a 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3bfe7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e9c3 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000301da5ed 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000301dd310 24. ./build_docker/./src/Interpreters/ActionsDAG.cpp:384: DB::ActionsDAG::addCast(DB::ActionsDAG::Node const&, std::shared_ptr const&, String) @ 0x00000000301de856 25. ./build_docker/./src/Planner/Planner.cpp:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bff8aa 26. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:09:22.512746 [ 6023 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'inter' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002ca5118a 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3bfe7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e9c3 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 16. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 18. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. ./build_docker/./src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000301da5ed 23. ./build_docker/./src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000301dd310 24. ./build_docker/./src/Interpreters/ActionsDAG.cpp:384: DB::ActionsDAG::addCast(DB::ActionsDAG::Node const&, std::shared_ptr const&, String) @ 0x00000000301de856 25. ./build_docker/./src/Planner/Planner.cpp:815: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bff8aa 26. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:09:23.148168 [ 6019 ] {7e5150c5-65ba-412e-8877-f48a69446bab} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 24, line 31) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a05fc 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:23.150703 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a05fc 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:23.396823 [ 6027 ] {d39a90c0-b020-4857-8d0c-c06e4e3cc2a6} executeQuery: Code: 36. DB::Exception: The minimum value cannot be greater than the maximum value for function clamp: In scope SELECT clamp(1, 3, 2). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42846) (comment: 03036_clamp.sql) (query 14, line 14) (in query: select clamp(1, 3, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionClamp::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d107ecd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:09:23.400050 [ 6027 ] {} TCPHandler: Code: 36. DB::Exception: The minimum value cannot be greater than the maximum value for function clamp: In scope SELECT clamp(1, 3, 2). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionClamp::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d107ecd 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:09:23.510916 [ 6164 ] {c653230b-9e3d-43ee-9e3a-af133353b136} ExternalDictionariesLoader: Could not update external dictionary '2a13da8a-e669-47b0-8ee1-14bf972efd8b', leaving the previous version: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:211: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x00000000272e5730 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea37b 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:23.512763 [ 6029 ] {c653230b-9e3d-43ee-9e3a-af133353b136} executeQuery: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46334) (comment: 02504_regexp_dictionary_table_source.sql) (query 22, line 59) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:211: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x00000000272e5730 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea37b 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:09:23.514707 [ 6029 ] {} TCPHandler: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:211: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x00000000272e5730 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea37b 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:23.988645 [ 6023 ] {72744a5f-9fcd-45ff-83a2-7fa0ccac0437} executeQuery: Code: 44. DB::Exception: Illegal column UInt64 of argument of function reverse: while executing 'FUNCTION reverse(__table1.inter :: 0) -> reverse(__table1.inter) UInt64 : 1'. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42852) (comment: 02233_interpolate_1.sql) (query 6, line 26) (in query: # Test INTERPOLATE with incompatible expression - should produce error SELECT n, source, inter FROM ( SELECT toFloat32(number % 10) AS n, 'original' AS source, number as inter FROM numbers(10) WHERE number % 3 = 1 ) ORDER BY n WITH FILL FROM 0 TO 11.51 STEP 0.5 INTERPOLATE (inter AS reverse(inter));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::(anonymous namespace)::FunctionReverse::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a33580d 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 11. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:391: DB::FillingTransform::interpolate(std::vector::mutable_ptr, std::allocator::mutable_ptr>> const&, DB::Block&) @ 0x000000003c114bb9 12. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:635: DB::FillingTransform::transformRange(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>> const&, std::vector> const&, std::vector> const&, std::vector> const&, std::vector> const&, std::pair, bool) @ 0x000000003c119d9b 13. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:792: DB::FillingTransform::transform(DB::Chunk&) @ 0x000000003c11ca44 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:09:23.995444 [ 6023 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column UInt64 of argument of function reverse: while executing 'FUNCTION reverse(__table1.inter :: 0) -> reverse(__table1.inter) UInt64 : 1'. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::(anonymous namespace)::FunctionReverse::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a33580d 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 11. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:391: DB::FillingTransform::interpolate(std::vector::mutable_ptr, std::allocator::mutable_ptr>> const&, DB::Block&) @ 0x000000003c114bb9 12. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:635: DB::FillingTransform::transformRange(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>> const&, std::vector> const&, std::vector> const&, std::vector> const&, std::vector> const&, std::pair, bool) @ 0x000000003c119d9b 13. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:792: DB::FillingTransform::transform(DB::Chunk&) @ 0x000000003c11ca44 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:24.205052 [ 5218 ] {90836e4b-00dc-4d1e-a624-08ee765f9c25} ExternalDictionariesLoader: Could not update external dictionary '2a13da8a-e669-47b0-8ee1-14bf972efd8b', leaving the previous version: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e94fa 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:24.206312 [ 6029 ] {90836e4b-00dc-4d1e-a624-08ee765f9c25} executeQuery: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46334) (comment: 02504_regexp_dictionary_table_source.sql) (query 25, line 64) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e94fa 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:09:24.208387 [ 6029 ] {} TCPHandler: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e94fa 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:24.241764 [ 6019 ] {74b728ae-3512-4611-af90-6136f2d10b73} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 40, line 55) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19fc60 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:24.244451 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19fc60 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:24.276731 [ 6019 ] {43131ea3-2f41-4d80-a14f-8be0416196ed} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 41, line 56) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:24.278753 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:24.320835 [ 6019 ] {4a543004-c005-4c07-910d-0c2331368f40} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 42, line 57) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:24.323817 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:24.379220 [ 6019 ] {e1ed77b8-df0f-414a-a257-6c6a1d169cfe} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 43, line 59) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a05fc 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:24.382690 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a05fc 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.054367 [ 6027 ] {b667c243-406f-4452-9b9d-2e5763b5575b} executeQuery: Code: 36. DB::Exception: The minimum value cannot be greater than the maximum value for function clamp: while executing 'FUNCTION clamp(1_UInt8 :: 2, arrayElement(__table1.data, 1_UInt8) :: 1, arrayElement(__table1.data, 2_UInt8) :: 5) -> clamp(1_UInt8, arrayElement(__table1.data, 1_UInt8), arrayElement(__table1.data, 2_UInt8)) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42846) (comment: 03036_clamp.sql) (query 15, line 15) (in query: select clamp(1, data[1], data[2])from (select arrayJoin([[1, 2], [2,3], [3,2], [4, 4]]) as data);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionClamp::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d107ecd 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.058069 [ 6027 ] {} TCPHandler: Code: 36. DB::Exception: The minimum value cannot be greater than the maximum value for function clamp: while executing 'FUNCTION clamp(1_UInt8 :: 2, arrayElement(__table1.data, 1_UInt8) :: 1, arrayElement(__table1.data, 2_UInt8) :: 5) -> clamp(1_UInt8, arrayElement(__table1.data, 1_UInt8), arrayElement(__table1.data, 2_UInt8)) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionClamp::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d107ecd 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.331757 [ 5164 ] {aa4297cb-6d5a-4262-bf9a-83f3cce6170a} ExternalDictionariesLoader: Could not update external dictionary '2a13da8a-e669-47b0-8ee1-14bf972efd8b', leaving the previous version: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:304: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e965b 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:25.333110 [ 6029 ] {aa4297cb-6d5a-4262-bf9a-83f3cce6170a} executeQuery: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46334) (comment: 02504_regexp_dictionary_table_source.sql) (query 30, line 71) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:304: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e965b 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.335407 [ 6029 ] {} TCPHandler: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:304: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e965b 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.467861 [ 6023 ] {7d905ff5-476b-4882-9eef-d19567746ea5} executeQuery: Code: 475. DB::Exception: Column '__table1.n' is participating in ORDER BY ... WITH FILL expression and can't be INTERPOLATE output. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42852) (comment: 02233_interpolate_1.sql) (query 7, line 31) (in query: # Test INTERPOLATE with column from WITH FILL expression - should produce error SELECT n, source, inter FROM ( SELECT toFloat32(number % 10) AS n, 'original' AS source, number as inter FROM numbers(10) WHERE number % 3 = 1 ) ORDER BY n WITH FILL FROM 0 TO 11.51 STEP 0.5 INTERPOLATE (n AS n);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:246: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c11186d 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c10660e 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c105a25 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1dce66 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f1dbfd9 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f234f41 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1044b4 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.471554 [ 6023 ] {} TCPHandler: Code: 475. DB::Exception: Column '__table1.n' is participating in ORDER BY ... WITH FILL expression and can't be INTERPOLATE output. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:246: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c11186d 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c10660e 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c105a25 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1dce66 8. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f1dbfd9 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f234f41 10. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1044b4 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.749019 [ 6019 ] {0536a838-49a3-400e-9f41-5d2886558750} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 59, line 83) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19fc60 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.750904 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19fc60 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.858938 [ 6019 ] {c3bb7215-5aac-467f-b015-6bb1bf145e20} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 60, line 84) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.861554 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.897455 [ 6019 ] {6d6b964c-ffaf-4ec6-a125-38d69755f261} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 61, line 85) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.899849 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:25.951083 [ 6019 ] {00e599d2-2985-45a4-89b8-dc31f150c7c4} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 62, line 87) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a05fc 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:26.040650 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a05fc 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:26.606604 [ 3941 ] {52ea7930-4d0e-4a33-8aa7-ab50a5c68edb} ExternalDictionariesLoader: Could not update external dictionary '2a13da8a-e669-47b0-8ee1-14bf972efd8b', leaving the previous version: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:334: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ec54d 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:26.608020 [ 6029 ] {52ea7930-4d0e-4a33-8aa7-ab50a5c68edb} executeQuery: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46334) (comment: 02504_regexp_dictionary_table_source.sql) (query 38, line 82) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:334: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ec54d 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:09:26.610887 [ 6029 ] {} TCPHandler: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:334: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ec54d 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:26.869387 [ 5196 ] {ce98f8ea-7cc9-4005-b24f-158d82012626} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43446) (comment: 02504_regexp_dictionary_table_source.sql) (in query: DROP DATABASE IF EXISTS test_8nwoca4w SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:26.871285 [ 5196 ] {ce98f8ea-7cc9-4005-b24f-158d82012626} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:27.527766 [ 6072 ] {c9bf7bda-e0d3-4b56-be90-880dc68b8c63} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=797, jobs=775). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46496) (comment: 02884_interval_operator_support_plural_literal.sql) (query 6, line 6) (in query: SELECT INTERVAL '2 months';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:09:27.531710 [ 6072 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=797, jobs=775). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:09:27.587768 [ 6019 ] {514431ca-b7eb-41b9-9dfc-9a19ab7588d6} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 78, line 111) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t AND A.t < B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19fc60 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:27.589917 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple inequality predicates in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:606: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19fc60 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:27.618743 [ 6019 ] {1c20a955-cd82-47fc-9f61-fbc2560bdab4} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 79, line 112) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t == B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:27.621071 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b, __table1.t = __table2.t)]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:27.683969 [ 6019 ] {19521db6-857c-416d-a554-e5f0be41c389} executeQuery: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 80, line 113) (in query: SELECT count() FROM A ASOF JOIN B ON A.a == B.b AND A.t != B.t;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:27.686469 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join requires one inequality predicate in JOIN ON expression, in [Predcates: (__table1.a = __table2.b) Residual filter: ((notEquals(__table1.t, __table2.t)))]. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:612: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a024c 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:27.731807 [ 6019 ] {2de23dd0-e3e8-48a0-81e8-8d6fd3b9dc6d} executeQuery: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42816) (comment: 00976_asof_join_on.gen.sql) (query 81, line 115) (in query: SELECT A.a, A.t, B.b, B.t FROM A ASOF JOIN B ON A.a == B.b AND A.t < B.t OR A.a == B.b + 1 ORDER BY (A.a, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a05fc 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:27.733815 [ 6019 ] {} TCPHandler: Code: 403. DB::Exception: ASOF join does not support multiple disjuncts in JOIN ON expression. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:592: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c1a05fc 5. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 7. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:28.247299 [ 6023 ] {08122569-d1a9-43c3-8883-69672daa615c} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse UInt64 from String, because value is too short: while executing 'FUNCTION _CAST(__table1.source :: 0, 'UInt64'_String :: 1) -> __table1.source UInt64 : 2'. (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42852) (comment: 02233_interpolate_1.sql) (query 8, line 36) (in query: # Test INTERPOLATE with inconsistent column - should produce error SELECT n, source, inter FROM ( SELECT toFloat32(number % 10) AS n, 'original' AS source, number as inter FROM numbers(10) WHERE number % 3 = 1 ) ORDER BY n WITH FILL FROM 0 TO 11.51 STEP 0.5 INTERPOLATE (inter AS source);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000001f9dd64c 5. void DB::readIntTextImpl(unsigned long&, DB::ReadBuffer&) @ 0x000000000f1278e2 6. ./src/IO/ReadHelpers.h:508: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002ca50efe 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3bfe7 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e9c3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 17. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 23. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:391: DB::FillingTransform::interpolate(std::vector::mutable_ptr, std::allocator::mutable_ptr>> const&, DB::Block&) @ 0x000000003c114bb9 24. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:635: DB::FillingTransform::transformRange(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>> const&, std::vector> const&, std::vector> const&, std::vector> const&, std::vector> const&, std::pair, bool) @ 0x000000003c119d9b 25. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:792: DB::FillingTransform::transform(DB::Chunk&) @ 0x000000003c11ca44 26. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 27. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 2025.11.13 09:09:28.251000 [ 6023 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: Cannot parse UInt64 from String, because value is too short: while executing 'FUNCTION _CAST(__table1.source :: 0, 'UInt64'_String :: 1) -> __table1.source UInt64 : 2'. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000001f9dd64c 5. void DB::readIntTextImpl(unsigned long&, DB::ReadBuffer&) @ 0x000000000f1278e2 6. ./src/IO/ReadHelpers.h:508: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002ca50efe 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3bfe7 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e9c3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 17. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 23. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:391: DB::FillingTransform::interpolate(std::vector::mutable_ptr, std::allocator::mutable_ptr>> const&, DB::Block&) @ 0x000000003c114bb9 24. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:635: DB::FillingTransform::transformRange(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector::mutable_ptr, std::allocator::mutable_ptr>> const&, std::vector> const&, std::vector> const&, std::vector> const&, std::vector> const&, std::pair, bool) @ 0x000000003c119d9b 25. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:792: DB::FillingTransform::transform(DB::Chunk&) @ 0x000000003c11ca44 26. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 27. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:28.507037 [ 4464 ] {9a9a56ea-801d-4e4a-9fdf-afd61c0ada62} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=797, jobs=774). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46580) (comment: 02955_analyzer_using_functional_args.gen.sql) (query 4, line 7) (in query: -- { echoOff } SELECT 'ALIAS';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:09:28.510467 [ 4464 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=797, jobs=774). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:09:29.887612 [ 6079 ] {2ec446f2-d090-47df-af0c-493477dd4941} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43496) (comment: 03290_mix_engine_and_query_settings.sql) (in query: DROP DATABASE IF EXISTS test_tn0dahxd SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:29.889940 [ 6079 ] {2ec446f2-d090-47df-af0c-493477dd4941} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:30.831365 [ 3727 ] {a61855eb-0cf4-4786-b9d3-2cfad95dabe2::0_1_1_0_13} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:30.832024 [ 3727 ] {a61855eb-0cf4-4786-b9d3-2cfad95dabe2::0_1_1_0_13} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:230: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032eb6bd6 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000003a0a6ec1 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000003a0a4916 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:30.832547 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a61855eb-0cf4-4786-b9d3-2cfad95dabe2::0_1_1_0_13}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:230: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032eb6bd6 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000003a0a6ec1 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000003a0a4916 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:30.863642 [ 3729 ] {a61855eb-0cf4-4786-b9d3-2cfad95dabe2::8_9_9_0_13} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:30.864301 [ 3729 ] {a61855eb-0cf4-4786-b9d3-2cfad95dabe2::8_9_9_0_13} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:230: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032eb6bd6 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000003a0a6ec1 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000003a0a4916 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:30.864904 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a61855eb-0cf4-4786-b9d3-2cfad95dabe2::8_9_9_0_13}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:230: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032eb6bd6 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000003a0a6ec1 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000003a0a4916 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:32.866557 [ 6092 ] {16632e46-b60c-482c-8127-aa67284ea42b} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_13.txt' with part '0_1_1_0_12' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x00000000339eeec6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 . (UNFINISHED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46588) (comment: 02932_apply_deleted_mask.sql) (query 17, line 31) (in query: DELETE FROM t_materialize_delete WHERE id % 7 = 4;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x00000000339eeec6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:32.870945 [ 6092 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_13.txt' with part '0_1_1_0_12' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x00000000339eeec6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x00000000339eeec6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:09:33.245001 [ 5803 ] {38d106d8-62f0-4268-8e8d-0d95f9e214a3} executeQuery: Code: 481. DB::Exception: SQLite database file path '/etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53056) (comment: 02918_sqlite_path_check.sh) (query 1, line 1) (in query: Select * from sqlite('/etc/passwd', 'something');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002d1f3fbb 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:37: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002d1f6590 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:49: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002d1f7105 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000268043eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:09:33.250115 [ 5803 ] {} TCPHandler: Code: 481. DB::Exception: SQLite database file path '/etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002d1f3fbb 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:37: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002d1f6590 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:49: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002d1f7105 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000268043eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:09:34.183989 [ 4221 ] {23222600-458a-477e-a20a-058bced0b9a1} executeQuery: Code: 481. DB::Exception: SQLite database file path '../../../../etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53118) (comment: 02918_sqlite_path_check.sh) (query 1, line 1) (in query: Select * from sqlite('../../../../etc/passwd', 'something');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002d1f3fbb 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:37: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002d1f6590 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:49: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002d1f7105 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000268043eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:09:34.187275 [ 4221 ] {} TCPHandler: Code: 481. DB::Exception: SQLite database file path '../../../../etc/passwd' must be inside 'user_files' directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:22: DB::processSQLiteError(String const&, bool) @ 0x000000002d1f3fbb 4. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:37: DB::validateSQLiteDatabasePath(String const&, String const&, bool, bool) @ 0x000000002d1f6590 5. ./build_docker/./src/Databases/SQLite/SQLiteUtils.cpp:49: DB::openSQLiteDB(String const&, std::shared_ptr, bool) @ 0x000000002d1f7105 6. ./build_docker/./src/TableFunctions/TableFunctionSQLite.cpp:91: DB::(anonymous namespace)::TableFunctionSQLite::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000268043eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:09:37.003549 [ 6079 ] {192e2453-ee64-43d7-90b6-94532f0fdba8} executeQuery: Code: 57. DB::Exception: Table test_7.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53092) (comment: 03208_array_of_json_read_subcolumns_1.gen.sql) (query 24, line 35) (in query: CREATE TABLE test (`id` UInt64, `json` JSON(max_dynamic_paths = 8, `a.b` Array(JSON))) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1000000000, min_bytes_for_wide_part = 10000000000, index_granularity = 11777, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 433868153, compact_parts_max_bytes_to_buffer = 473464927, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 13734846, merge_max_block_size = 14599, old_parts_lifetime = 96., prefer_fetch_merged_part_size_threshold = 9939364706, vertical_merge_algorithm_min_rows_to_activate = 446390, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6604572669, index_granularity_bytes = 20421884, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 86, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 57703, primary_key_compress_block_size = 40868, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:09:37.006621 [ 6079 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:09:37.536932 [ 5803 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled: while executing 'FUNCTION sleep(1_UInt8 :: 0) -> sleep(1_UInt8) UInt8 : 1'. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001a6035bd 8. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6029ba 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 15. ./build_docker/./src/Storages/VirtualColumnUtils.cpp:105: DB::VirtualColumnUtils::filterBlockWithExpression(std::shared_ptr const&, DB::Block&) @ 0x0000000038ee4edc 16. ./build_docker/./src/Storages/VirtualColumnUtils.cpp:513: DB::VirtualColumnUtils::filterBlockWithPredicate(DB::ActionsDAG::Node const*, DB::Block&, std::shared_ptr, bool) @ 0x0000000038efb29d 17. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7456: DB::MergeTreeData::getMinMaxCountProjectionBlock(std::shared_ptr const&, std::vector> const&, DB::ActionsDAG const*, std::vector, std::allocator>> const&, std::unordered_map, std::equal_to, std::allocator>> const*, std::shared_ptr) const @ 0x0000000039a0026a 18. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:488: DB::QueryPlanOptimizations::getAggregateProjectionCandidates(DB::QueryPlan::Node&, DB::AggregatingStep&, DB::ReadFromMergeTree&, std::shared_ptr, std::equal_to, std::allocator>>> const&, bool) @ 0x000000003c564f33 19. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:592: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c56a812 20. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c478e 21. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:09:44.626716 [ 6019 ] {1ef75ed4-6c91-42e0-a125-b31e1a74880c} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456789000000000 by scale -6101065173709551616: In scope SELECT toDecimal64(toDecimal64('1234567890', 8), 10). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 4, line 5) (in query: SELECT toDecimal64(toDecimal64('1234567890', 8), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:44.628860 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456789000000000 by scale -6101065173709551616: In scope SELECT toDecimal64(toDecimal64('1234567890', 8), 10). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:45.942632 [ 6072 ] {36392ffa-bd5d-4d21-883f-38cd69b05b92} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51404) (comment: 03012_prewhere_merge_distributed.sql) (query 10, line 17) (in query: SELECT count() AS `count()` FROM `test_7`.`test_local` AS `__table1` PREWHERE `__table1`.`name` GLOBAL IN (`_data_1194095428404230657_5873479095190591143` AS `__table2`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eeed2a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ee4a84 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039ee43c9 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039ba06ba 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b8f2f5 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13d1f 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:282: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b8cf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:161: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3e28b7 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c2eb3f4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:09:45.949091 [ 6072 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eeed2a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ee4a84 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039ee43c9 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039ba06ba 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b8f2f5 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13d1f 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:282: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b8cf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:161: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3e28b7 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c2eb3f4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:46.399830 [ 6023 ] {c6ad885d-2963-49d6-a3dd-6844c2b58fef} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eeed2a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ee4a84 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039ee43c9 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039ba06ba 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b8f2f5 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13d1f 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:282: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b8cf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:161: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3e28b7 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c2eb3f4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48028) (comment: 03012_prewhere_merge_distributed.sql) (query 10, line 17) (in query: SELECT count() FROM merge(currentDatabase(), '^test_distributed$') PREWHERE name GLOBAL IN ( SELECT name FROM test_distributed );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:09:46.409541 [ 6023 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eeed2a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ee4a84 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039ee43c9 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039ba06ba 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b8f2f5 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13d1f 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:282: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b8cf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:161: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3e28b7 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c2eb3f4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:47.505383 [ 6019 ] {78c97221-7580-4e5f-b8b3-9f7d5d44a4c4} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456780 by scale -539223888: In scope SELECT toDecimal32(toDecimal32('12345678', 1), 3). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 6, line 8) (in query: SELECT toDecimal32(toDecimal32('12345678', 1), 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42e901 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d2fa 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce82a7e 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce560ef 8. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94e88d 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:47.508318 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456780 by scale -539223888: In scope SELECT toDecimal32(toDecimal32('12345678', 1), 3). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42e901 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d2fa 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce82a7e 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce560ef 8. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94e88d 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:47.526673 [ 6019 ] {03e1b3ab-4d36-4ff6-96d6-59ec28d0d52c} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying 922337203685477581 by scale -9223372036854775806: In scope SELECT toDecimal64(toDecimal64('92233720368547758.1', 1), 2). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 7, line 10) (in query: SELECT toDecimal64(toDecimal64('92233720368547758.1', 1), 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:47.531093 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying 922337203685477581 by scale -9223372036854775806: In scope SELECT toDecimal64(toDecimal64('92233720368547758.1', 1), 2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:47.545554 [ 6019 ] {ac0db561-943f-419c-b20e-dd68379c993b} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying -922337203685477581 by scale 9223372036854775806: In scope SELECT toDecimal64(toDecimal64('-92233720368547758.1', 1), 2). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 8, line 11) (in query: SELECT toDecimal64(toDecimal64('-92233720368547758.1', 1), 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:47.547637 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying -922337203685477581 by scale 9223372036854775806: In scope SELECT toDecimal64(toDecimal64('-92233720368547758.1', 1), 2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:49.252049 [ 2997 ] {50ee0566-5f43-4ed7-9e15-1c57d7544913} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60006.311384 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48546) (comment: 00284_external_aggregation.sql) (query 6, line 12) (in query: SELECT sum(k), sum(c) FROM (SELECT number AS k, count() AS c FROM (SELECT * FROM system.numbers LIMIT 10000000) GROUP BY k);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:09:49.271526 [ 2997 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60006.311384 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:49.533515 [ 6019 ] {59814fab-9e36-4813-9886-27e41f04e4e2} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 10, line 14) (in query: SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x000000002f4493d0 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451915 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb2959d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb180d9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c943723 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9736bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c972602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:49.536712 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x000000002f4493d0 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451915 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb2959d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb180d9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c943723 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9736bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c972602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:49.626618 [ 6019 ] {5967bd30-1756-4bc3-bc39-9718ea407354} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(-x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 11, line 15) (in query: SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(-x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x000000002f4493d0 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451915 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb2959d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb180d9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c943723 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9736bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c972602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:49.629515 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(-x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x000000002f4493d0 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451915 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb2959d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb180d9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c943723 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9736bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c972602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:50.653979 [ 4464 ] {} TCPHandler: TCPHandler: Code: 101. DB::Exception: Unexpected packet from client (expected Hello, got 22). (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Server/TCPHandler.cpp:1671: DB::TCPHandler::receiveHello() @ 0x000000003aebc93b 5. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:50.654211 [ 4464 ] {} ServerErrorHandler: Code: 101. DB::Exception: Unexpected packet from client (expected Hello, got 22). (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Server/TCPHandler.cpp:1671: DB::TCPHandler::receiveHello() @ 0x000000003aebc93b 5. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:51.036225 [ 5639 ] {5e5a4dbe-8981-4be7-9172-8bcce41b986e} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 8 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_g6n8lhk7_data1.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02305_schema_inference_with_globs.sh) (query 1, line 1) (in query: desc file('02305_schema_inference_with_globs_test_g6n8lhk7_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=8, input_format_json_infer_incomplete_types_as_strings=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a3f964d 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ecbe8 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ca33 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:51.040075 [ 5639 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 8 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_g6n8lhk7_data1.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a3f964d 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ecbe8 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ca33 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:51.472954 [ 4964 ] {eca0d98b-08ca-411f-8310-cd4519cbf4b1} executeQuery: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48310) (comment: 02695_storage_join_insert_select_deadlock.sql) (query 4, line 11) (in query: INSERT INTO test_table_join SELECT * from test_table_join;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:329: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x00000000385e58d2 5. ./build_docker/./src/Storages/StorageSet.cpp:107: DB::SetOrJoinSink::consume(DB::Chunk&) @ 0x0000000038d425a6 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:09:51.657600 [ 6019 ] {1e2e8f30-5c4b-4075-9033-0398ede4dc69} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('2147483649', 10) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 15, line 20) (in query: SELECT toDecimal128('2147483649', 10) AS x, toInt32(x), toInt32(-x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, int&) @ 0x000000002f443f39 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450dd5 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb030dd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caf2c99 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c942aa3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96febd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96ee02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:51.660185 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('2147483649', 10) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, int&) @ 0x000000002f443f39 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450dd5 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb030dd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caf2c99 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c942aa3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96febd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96ee02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:51.932408 [ 4964 ] {} TCPHandler: Code: 473. DB::Exception: StorageJoin: cannot insert data because current query tries to read from this storage. (DEADLOCK_AVOIDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageJoin.cpp:329: DB::StorageJoin::insertBlock(DB::Block const&, std::shared_ptr) @ 0x00000000385e58d2 5. ./build_docker/./src/Storages/StorageSet.cpp:107: DB::SetOrJoinSink::consume(DB::Chunk&) @ 0x0000000038d425a6 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:09:52.710575 [ 5196 ] {f46df733-4aa6-413e-a2ef-b6e17f14c15f} executeQuery: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 6 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_g6n8lhk7_data2.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44154) (comment: 02305_schema_inference_with_globs.sh) (query 1, line 1) (in query: desc file('02305_schema_inference_with_globs_test_g6n8lhk7_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=16, input_format_json_infer_incomplete_types_as_strings=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:495: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ecefe 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ca33 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:52.714006 [ 5196 ] {} TCPHandler: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 6 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_g6n8lhk7_data2.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:495: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ecefe 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ca33 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:52.824584 [ 4964 ] {5e2a8c6c-c009-4b5b-8e61-0ba925ab4341} executeQuery: Code: 264. DB::Exception: Table test_7.test_table_join (9860a502-2106-4cd5-8526-b7fc8847bbb2) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48310) (comment: 02695_storage_join_insert_select_deadlock.sql) (query 5, line 13) (in query: INSERT INTO test_table_join SELECT * FROM (SELECT 1 as id) AS t1 ANY LEFT JOIN test_table_join USING (id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e3d25 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:579: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ad5a3e 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000032ae00c9 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:09:52.828281 [ 4964 ] {} TCPHandler: Code: 264. DB::Exception: Table test_7.test_table_join (9860a502-2106-4cd5-8526-b7fc8847bbb2) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e3d25 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:579: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ad5a3e 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000032ae00c9 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:09:53.693870 [ 5196 ] {3e347b99-cff9-424a-bac8-33c8178d7984} executeQuery: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 4 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_g6n8lhk7_data3.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44182) (comment: 02305_schema_inference_with_globs.sh) (query 1, line 1) (in query: desc file('02305_schema_inference_with_globs_test_g6n8lhk7_data*.jsonl') settings input_format_max_rows_to_read_for_schema_inference=24, input_format_json_infer_incomplete_types_as_strings=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:495: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ecefe 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ca33 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:53.694751 [ 6019 ] {9ababd3b-5d6d-4a44-a31b-ba973cf0d08a} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('2147483649', 2) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 17, line 22) (in query: SELECT toDecimal64('2147483649', 2) AS x, toInt32(x), toInt32(-x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450d03 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb0261d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caf2959 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c942dd9 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96febd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96ee02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:09:53.696854 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('2147483649', 2) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450d03 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb0261d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caf2959 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c942dd9 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96febd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96ee02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:09:53.696946 [ 5196 ] {} TCPHandler: Code: 636. DB::Exception: All attempts to extract table structure from files failed. Errors: Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 10 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) Code: 652. DB::Exception: Cannot determine type for column 'x' by first 4 rows of data, most likely this column contains only Nulls or empty Arrays/Maps. You can specify the type for this column using setting schema_inference_hints. If your data contains complex JSON objects, try enabling one of the settings allow_experimental_object_type/input_format_json_read_objects_as_strings. (ONLY_NULLS_WHILE_READING_SCHEMA) (version 25.3.8.10072.altinitytest (altinity build)) To increase the maximum number of rows/bytes to read for structure determination, use setting input_format_max_rows_to_read_for_schema_inference/input_format_max_bytes_to_read_for_schema_inference You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02305_schema_inference_with_globs_test_g6n8lhk7_data3.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:495: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ecefe 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:119: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ca33 9. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:09:54.999397 [ 6067 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: MySQL: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:54.999737 [ 6067 ] {} ServerErrorHandler: Code: 516. DB::Exception: MySQL: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:55.711858 [ 6019 ] {e4293205-2b88-4a7f-88b4-d2ceabbc2bf6} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 32, line 43) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:55.714065 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:57.730992 [ 6019 ] {6ccc2f89-bbd0-4cc1-b247-a8aff46c521c} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 33, line 44) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:57.780127 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:57.936898 [ 4964 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:57.937343 [ 4964 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:58.433690 [ 5803 ] {32522184-a93a-4b6c-94e8-a7fac69e9402} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44254) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:58.760460 [ 6070 ] {e404c138-5af8-4a95-acfd-853af09ed772} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=37, jobs=12): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/data.bin (position: 493845, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 438043283b39aac0067ccef921b3bd30828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 7 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44286) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:09:58.760773 [ 6023 ] {89264f4f-8481-4f20-8a6d-8a19f35af44d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=18): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_2_2_0/data.bin (position: 7045522, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 235faa426af87bdd4170f826ad0da7b8828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_2_2_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 107 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44300) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:09:58.761543 [ 6080 ] {3bca3f7d-9e15-4d8f-96b5-fc72682dd069} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=19): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_6_6_0/data.bin (position: 4675066, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6ae9c76fc6e6cafc6b503b468ec4e70c828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_6_6_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 71 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43024) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:09:58.764915 [ 5295 ] {20668c2f-cb0e-48aa-a594-5a8d2da03f9e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=22): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_2_2_0/data.bin (position: 8658749, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 871cd87c63d2f177a0414c5cd471bbab828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_2_2_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 131 with max_rows_to_read = 63377): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44244) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:09:58.854345 [ 6023 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=18): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_2_2_0/data.bin (position: 7045522, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 235faa426af87bdd4170f826ad0da7b8828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_2_2_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 107 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:58.863419 [ 5295 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=22): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_2_2_0/data.bin (position: 8658749, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 871cd87c63d2f177a0414c5cd471bbab828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_2_2_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 131 with max_rows_to_read = 63377): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:58.865683 [ 5803 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:58.884676 [ 6080 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=19): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_6_6_0/data.bin (position: 4675066, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6ae9c76fc6e6cafc6b503b468ec4e70c828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_6_6_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 71 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:58.966253 [ 6070 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=37, jobs=12): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/data.bin (position: 493845, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 438043283b39aac0067ccef921b3bd30828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 7 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:59.108775 [ 6079 ] {5a4846ab-e106-4dc1-8219-c1b4cb5e598e} executeQuery: Code: 50. DB::Exception: Unknown BSON type: 0x00: While executing BSONEachRowRowInputFormat. (UNKNOWN_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44336) (comment: 02684_bson.sql) (query 1, line 1) (in query: -- It correctly throws exception about incorrect data: SELECT * FROM format('BSONEachRow', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int16, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, WindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$^WatchIDc*5/ !p~JavaEnableTitleGoodEventEventTime7��QEventDate>CounterIDClientIP��z�RegionIDGUserID� ��:6��CounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID��9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZone����ClientEventTime��SilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime&��QAgeSexIncomeInterestsRobotnessRemoteIP^DI�WindowName����OpenerName����HistoryLength����BrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHash�|3��b.�CLID^WatchID��F�ӓ2qJavaEnableTitleGoodEventEventTimen$�QEventDate>CounterIDClientIP��z�RegionIDGUserID� ��:6��CounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthmingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHashv�v����CLID�WatchID���\JavaEnableTitleGoodEventEventTime� �QEventDate>CounterIDClientIP�gURegionID�UserID�s�yy��fCounterClassOS,UserAgentURL1http://tours/Ekategoriya%2F&sr=http://slovareniyeRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID�ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID��TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZone����ClientEventTime��SilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeY��QAgeSexIncomeInterestsRobotnessRemoteIP�=kWindowName����OpenerName����HistoryLength����BrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHashh��9�DCLID^WatchID�/E��J�{JavaEnableTitleGoodEventEventTime�1�QEventDate>CounterIDClientIP��z�RegionIDGUserID� ��:6��CounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID��9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZone����ClientEventTime��SilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime���QAgeSexIncomeInterestsRobotnessRemoteIP^DI�WindowName����OpenerName����HistoryLength����BrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHash�|3��b.�CLID$$);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Formats/BSONTypes.cpp:23: DB::getBSONType(unsigned char) @ 0x000000003b3d96a8 5. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:794: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b3cbf51 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:09:59.119009 [ 6079 ] {} TCPHandler: Code: 50. DB::Exception: Unknown BSON type: 0x00: While executing BSONEachRowRowInputFormat. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Formats/BSONTypes.cpp:23: DB::getBSONType(unsigned char) @ 0x000000003b3d96a8 5. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:794: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b3cbf51 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:09:59.318027 [ 2997 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33518, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.318199 [ 5639 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:60702, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.318366 [ 4390 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45766, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.318473 [ 4714 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:56582, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.318583 [ 4464 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51886, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.318852 [ 2997 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33518, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.319054 [ 5196 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33520, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.319273 [ 5196 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33520, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.319726 [ 5927 ] {672fca15-97a9-49c7-96ee-9c2464425f14} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=10): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/data.bin (position: 1053536, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 5ae65330723615b58b6d9da1a3603f03828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 16 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44284) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:09:59.320744 [ 5639 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:60702, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.322095 [ 4390 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45766, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.323572 [ 4714 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:56582, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.324756 [ 4221 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51872, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.324767 [ 4464 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51886, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.325131 [ 4221 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51872, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.339062 [ 6019 ] {015fea64-38f6-45e7-acc7-4589b759eb86} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 34, line 45) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:59.341480 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:09:59.382727 [ 5927 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=10): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/data.bin (position: 1053536, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 5ae65330723615b58b6d9da1a3603f03828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 16 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:09:59.859879 [ 4550 ] {fd38feed-1ff6-44ff-8a42-c6759d914447} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:46056). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.892939 [ 6016 ] {1f9e7cfe-daf3-4285-b649-169f5e2d6368} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=39, jobs=29): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_1_0/data.bin (position: 8066046, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: af94f4f29aed1e6d92f6f476b3357c34828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_1_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 122 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44238) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:183: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c3a0 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 2025.11.13 09:09:59.892970 [ 4017 ] {fa061d16-d770-4439-b9d7-cf476cd52076} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=3): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_1_0/data.bin (position: 2666701, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: fc9d5da56b2159d0069810de46078229828a80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_1_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 40 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40166) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:183: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c3a0 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 2025.11.13 09:09:59.899241 [ 4170 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51078, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.902319 [ 4170 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51078, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.964712 [ 6027 ] {5b8fc894-8cc8-4802-8c16-17035b0e218a} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=19): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_6_6_0/data.bin (position: 4675066, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6ae9c76fc6e6cafc6b503b468ec4e70c828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_6_6_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 71 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44270) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:09:59.967571 [ 4145 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:41670, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:09:59.967887 [ 4145 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:41670, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:00.012320 [ 6016 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=39, jobs=29): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_1_0/data.bin (position: 8066046, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: af94f4f29aed1e6d92f6f476b3357c34828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_1_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 122 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:183: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c3a0 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:00.041209 [ 6027 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=19): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_6_6_0/data.bin (position: 4675066, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6ae9c76fc6e6cafc6b503b468ec4e70c828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_6_6_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 71 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:00.192610 [ 6028 ] {1abc1274-f993-4bc2-b3f7-0337cb0fcc87} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=10): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/data.bin (position: 1382766, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6faad825242e22f11fa88253039cdfb3828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 21 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44280) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:00.551329 [ 6019 ] {bf484ae5-8092-4204-b0db-d56ca6290eea} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 35, line 46) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt8(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, char8_t&) @ 0x000000002f4471c6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f512 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d7db6 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1df9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c3c3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:00.658363 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt8(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, char8_t&) @ 0x000000002f4471c6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f512 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d7db6 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1df9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c3c3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:00.686061 [ 4607 ] {e8a3d142-f7b9-4ab9-8810-4ae1c659d9a7} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:49016). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:00.747182 [ 6028 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=10): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/data.bin (position: 1382766, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6faad825242e22f11fa88253039cdfb3828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 21 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:00.855172 [ 4714 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: foo: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:00.856347 [ 4714 ] {} ServerErrorHandler: Code: 516. DB::Exception: foo: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:00.950983 [ 4017 ] {fa061d16-d770-4439-b9d7-cf476cd52076} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:40166). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x000000003aea5649 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:00.968533 [ 4017 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=3): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_1_0/data.bin (position: 2666701, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: fc9d5da56b2159d0069810de46078229828a80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_1_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 40 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:183: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c3a0 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:01.331309 [ 4389 ] {502c04e0-3aae-44ff-a9db-e30e77f754a2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50632) (comment: 02156_storage_merge_prewhere_not_ready_set_bug.sql) (in query: DROP DATABASE IF EXISTS test_w7xcrnra SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:01.336622 [ 4389 ] {502c04e0-3aae-44ff-a9db-e30e77f754a2} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:02.020877 [ 6092 ] {627137f3-cc72-4f8a-8cb0-a6a94a3ff9d3} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33510, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33510) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003aefd4ae 8. ./build_docker/./src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed460c 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:10:02.667594 [ 6019 ] {7f692193-19b1-4451-b506-f29d269df13d} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 36, line 48) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f45207a 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4b667 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3a899 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93eb39 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:02.731905 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f45207a 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4b667 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3a899 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93eb39 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:02.933355 [ 5803 ] {187d008a-f74c-487c-9957-ae7a96cbda33} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=3): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 3983683, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: e70b177b2402b96d2206d2f9937c0db6828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 60 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44376) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:02.942089 [ 6072 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46520, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:02.942421 [ 6072 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46520, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:03.062671 [ 6092 ] {627137f3-cc72-4f8a-8cb0-a6a94a3ff9d3} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:33510). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x000000003aea5649 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:03.066717 [ 6092 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33510, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003aefd4ae 8. ./build_docker/./src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed460c 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:10:03.066967 [ 5803 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=44, jobs=3): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 3983683, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: e70b177b2402b96d2206d2f9937c0db6828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 60 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:03.534954 [ 4715 ] {482bf30b-2f41-48ec-9a39-984bc7c616f2} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:55588). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:03.579164 [ 6023 ] {aabafcc9-8fe5-4aec-95a2-29b2e2c3db94} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/data.bin (position: 2172918, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 5b3371cedf4faf25b73801d4a5d952d4828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 33 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60718) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:03.623270 [ 6023 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/data.bin (position: 2172918, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 5b3371cedf4faf25b73801d4a5d952d4828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 33 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:04.157769 [ 2997 ] {975d4c05-2539-428a-ac16-c9bce1f0c581} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=1): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 6452908, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 8694d817236aa38c9a857812cfacc22e828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 98 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44414) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:04.187126 [ 6016 ] {2f95ee22-ea20-480e-8d96-1d50c81fd6ac} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:38118). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:04.300130 [ 6019 ] {9d9abf9d-d12f-4e7e-a7c1-26e6e3fd45ef} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 37, line 49) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:04.302239 [ 2997 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=1): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 6452908, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 8694d817236aa38c9a857812cfacc22e828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 98 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:04.303709 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:04.314342 [ 4550 ] {ad107731-3459-4bcb-b624-44a0c4f7c9d7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=2): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 10128703, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 4e8d18ea4286edba52f79686fe3ec7e3820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 304 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51896) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 2025.11.13 09:10:04.331246 [ 4550 ] {ad107731-3459-4bcb-b624-44a0c4f7c9d7} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:51896). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x000000003aea5649 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:04.338421 [ 4550 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=2): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 10128703, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 4e8d18ea4286edba52f79686fe3ec7e3820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 304 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:04.727483 [ 6023 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: foo: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:04.728280 [ 6023 ] {} ServerErrorHandler: Code: 516. DB::Exception: foo: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:05.330817 [ 4170 ] {3c59c33d-fa9b-43c2-9045-e3608eb3cc20} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=7): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 11318530, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: c69b673d76b632c010266e6b56d69150820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 328 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42044) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 2025.11.13 09:10:05.401455 [ 4017 ] {94a13850-6cd2-461f-8b4b-be649a51c61a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=2): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/data.bin (position: 65846, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: fecc3352f7723842e38652f935a724c9828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 1 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54788) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:05.406507 [ 4170 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=7): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 11318530, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: c69b673d76b632c010266e6b56d69150820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 328 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:05.413458 [ 4170 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:42044, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:05.413846 [ 4170 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:42044, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:05.476943 [ 4017 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=2): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/data.bin (position: 65846, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: fecc3352f7723842e38652f935a724c9828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 1 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:05.900630 [ 6070 ] {9367d3ef-1d02-44b5-855f-2dfbfc8c08ee} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 8856287, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6922479cc63f48e25779125e8f2199c58253680000e0670000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 134 with max_rows_to_read = 55800): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44386) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 2025.11.13 09:10:05.913769 [ 4529 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33900, local: [::ffff:127.0.0.10]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:05.915230 [ 4529 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33900, local: [::ffff:127.0.0.10]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:06.006665 [ 6070 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 8856287, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 6922479cc63f48e25779125e8f2199c58253680000e0670000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 134 with max_rows_to_read = 55800): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:06.038595 [ 6019 ] {8133f11f-bd10-4fbf-a059-427cf2610451} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 38, line 50) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:06.041590 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:06.169194 [ 10149 ] {3739365d-1f97-4ef3-8fb1-fb6ce7f13985} executeQuery: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types. (TYPE_MISMATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54826) (comment: 03034_dynamic_conversions.sql) (query 9, line 10) (in query: select number::Dynamic::Array(UInt64) as v from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x000000002c36b6bb 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c364338 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c31f2c1 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c31a528 8. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x000000002c33d03d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x000000002c33cc8e 10. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008eed6b1 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c33cba9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 22. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 23. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:10:06.176893 [ 10149 ] {} TCPHandler: Code: 53. DB::Exception: CAST AS Array can only be performed between same-dimensional Array, Map or String types. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::detail::FunctionCast::createArrayWrapper(std::shared_ptr const&, DB::DataTypeArray const&) const @ 0x000000002c36b6bb 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c364338 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c31f2c1 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c31a528 8. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x000000002c33d03d 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x000000002c33cc8e 10. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008eed6b1 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c33cba9 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 18. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 22. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 23. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:10:07.849948 [ 6019 ] {76b89651-327e-433a-b47d-21b62c2244dd} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 39, line 51) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt8(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f443 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d7043 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1ab9 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c6f9 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:07.853077 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt8(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f443 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d7043 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1ab9 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c6f9 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:08.443362 [ 4390 ] {0eaa08a5-6a5a-4ee8-b339-7bfd79430ff9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=6): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/data.bin (position: 6222447, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 64edef3cde27ea777b0056b10a41870f828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 94 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55478) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:08.493760 [ 4390 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=6): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/data.bin (position: 6222447, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 64edef3cde27ea777b0056b10a41870f828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 94 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:08.673176 [ 5927 ] {5e18117e-7e84-4007-8e0d-bf74fde74609} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=6): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/data.bin (position: 6222447, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 64edef3cde27ea777b0056b10a41870f828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 94 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44440) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:10:09.058828 [ 4964 ] {a250da03-d141-4b17-b6f1-3ac91e57cc4f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/data.bin (position: 1777842, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: f0e38af77e2abfeb5661e79a680a4d35828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 27 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54910) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:09.231447 [ 6028 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45470, local: [::ffff:127.0.0.10]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:09.232583 [ 6028 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45470, local: [::ffff:127.0.0.10]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:09.310421 [ 5927 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=6): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/data.bin (position: 6222447, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 64edef3cde27ea777b0056b10a41870f828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_8_8_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 94 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:09.328318 [ 4714 ] {14e4fc72-0dbd-4315-96dd-d4afe9a38c45} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:39664). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:09.347131 [ 10170 ] {226dc008-618d-4ee2-8623-95abf5357089} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:45500). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:09.385355 [ 4964 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/data.bin (position: 1777842, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: f0e38af77e2abfeb5661e79a680a4d35828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 27 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:09.416726 [ 4529 ] {7b6f759e-c67c-42f4-a249-e7fd1bbfa9f5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=0): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/data.bin (position: 131692, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: c80f4f5836b7e0528af4ada4a1debc25828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 2 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54918) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:09.423806 [ 10177 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47826, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:09.424099 [ 10177 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47826, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:09.424994 [ 2997 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45484, local: [::ffff:127.0.0.10]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:09.425459 [ 2997 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45484, local: [::ffff:127.0.0.10]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:09.486154 [ 4529 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=0): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/data.bin (position: 131692, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: c80f4f5836b7e0528af4ada4a1debc25828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_7_7_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 2 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:09.914618 [ 6019 ] {1992c459-ddc1-4222-b1fc-d14226393b32} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 40, line 53) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451e05 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4abac 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3a559 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e84d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:09.917801 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451e05 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4abac 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3a559 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e84d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:10.235667 [ 6027 ] {6287c463-0258-4abc-9925-e04be4e6526b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=3): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 8000289, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7a645d80183faad8f7eb978f4540f02a828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 121 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42496) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:10.300407 [ 6027 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=3): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 8000289, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7a645d80183faad8f7eb978f4540f02a828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 121 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:10.698544 [ 6072 ] {94ef9de5-cade-49fc-b0ec-c11a6d3b941a} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=3): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 8000289, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7a645d80183faad8f7eb978f4540f02a828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 121 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54842) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:10:10.703118 [ 5803 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46466, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:10.704510 [ 5803 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46466, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:10.742873 [ 6072 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=3): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 8000289, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 7a645d80183faad8f7eb978f4540f02a828b80000000800000): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 121 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:11.655564 [ 6019 ] {994c1a2b-ed79-46d8-bfb1-bae0c2df4689} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 41, line 54) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4512e5 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24387 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca14e39 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93dbcd 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:11.658064 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4512e5 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24387 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca14e39 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93dbcd 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:13.315259 [ 4715 ] {b28335ac-4e5f-45c3-9c9f-87274c5db26e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=909, jobs=900). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55492) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:10:13.324067 [ 4715 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=909, jobs=900). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:10:13.388392 [ 6092 ] {f92e5ce7-2cd5-4475-90d7-7a95ab3e4a47} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=909, jobs=900). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60528) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:10:13.417854 [ 6092 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=909, jobs=900). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:13.617996 [ 10609 ] {ced2f492-2bde-4a29-8408-6df574d64d49} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument for aggregate function deltaSumTimestamp, this type is not supported. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60518) (comment: 03272_bad_aggregate_function.sql) (query 1, line 1) (in query: SELECT deltaSumTimestamp(1, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a2e342d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:244: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020a68ed8 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:10:13.620904 [ 10609 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument for aggregate function deltaSumTimestamp, this type is not supported. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a2e342d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:244: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020a68ed8 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:10:13.681221 [ 6019 ] {fe17b90b-fe36-43a6-8426-16fd32334cb6} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 42, line 55) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450368 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9fefbd 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9ef8d9 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf4d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:13.690969 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450368 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9fefbd 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9ef8d9 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf4d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:13.711781 [ 10149 ] {90f3e98a-d42c-4446-84e5-078418067894} executeQuery: Code: 6. DB::Exception: Cannot parse string '42.42' as UInt64: syntax error at position 2 (parsed just '42'). Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(__table1.d :: 2, 'UInt64'_String :: 1) -> CAST(__table1.d, 'UInt64'_String) UInt64 : 0'. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54826) (comment: 03034_dynamic_conversions.sql) (query 26, line 31) (in query: select d::UInt64 from test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002ca5118a 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3bfe7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e9c3 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 15. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x000000002c33d1ea 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x000000002c33cc8e 17. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008eed6b1 18. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c33cba9 19. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 2025.11.13 09:10:13.732023 [ 10149 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '42.42' as UInt64: syntax error at position 2 (parsed just '42'). Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION CAST(__table1.d :: 2, 'UInt64'_String :: 1) -> CAST(__table1.d, 'UInt64'_String) UInt64 : 0'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002ca5118a 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3bfe7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e9c3 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 15. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x000000002c33d1ea 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x000000002c33cc8e 17. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008eed6b1 18. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c33cba9 19. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:14.315046 [ 6005 ] {0edbe2ee-eaa5-4da6-9a45-7a9431259c0a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56202) (comment: 02378_analyzer_projection_names.sql) (in query: DROP DATABASE IF EXISTS test_xrr73wtk SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:14.325623 [ 6005 ] {0edbe2ee-eaa5-4da6-9a45-7a9431259c0a} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:15.084323 [ 4714 ] {8d2b72b7-4324-4039-af13-b6a5845467ea} executeQuery: Code: 210. DB::Exception: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:59798): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59798) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1412: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl[abi:ne190107] (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000003af12259 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039f461f8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039f39892 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:154: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3d704f 10. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c2eb3f4 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:10:15.095219 [ 4714 ] {} TCPHandler: Code: 210. DB::Exception: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:59798): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1412: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl[abi:ne190107] (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000003af12259 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039f461f8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039f39892 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:154: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3d704f 10. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c2eb3f4 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:15.097529 [ 6019 ] {4c36a71d-7896-4fad-8fb0-ad639d3e5490} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 43, line 56) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt8(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f1a7 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d62a3 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1779 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c40d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:15.099675 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt8(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f1a7 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d62a3 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1779 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c40d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:15.337303 [ 6019 ] {92e07eee-badd-49a5-b670-861c8f8471b6} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 0) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 45, line 59) (in query: SELECT toDecimal128('18446744073709551616', 0) AS x, toUInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:15.340049 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 0) AS x, toUInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:15.439367 [ 6019 ] {5c5d64fb-c95a-4e4a-94f0-4025e5a45370} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 8) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 47, line 61) (in query: SELECT toDecimal128('18446744073709551616', 8) AS x, toUInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:15.442737 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 8) AS x, toUInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:15.522270 [ 6019 ] {11733f61-ab76-4661-aadd-44d3465338fa} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 49, line 64) (in query: SELECT toDecimal128('4294967296', 0) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:15.525095 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:15.531690 [ 2997 ] {69f9435f-3977-456f-9cdb-ea6baa1a533f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=4): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 26195313, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: a88045d5d8f8c663779af5e64fd8a82d820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 792 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54980) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 2025.11.13 09:10:15.561844 [ 4964 ] {a5774d92-a4f7-445d-a5cc-650355e4d15d} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:39688). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:15.632196 [ 6019 ] {15a7453e-44c4-4d4f-8dd1-b6518ad6e5b0} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 10) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 51, line 66) (in query: SELECT toDecimal128('4294967296', 10) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:15.635540 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 10) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:15.737647 [ 2997 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=4): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 26195313, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: a88045d5d8f8c663779af5e64fd8a82d820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 792 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:15.742262 [ 5295 ] {0cfe1ee5-edf3-400a-8b41-92d138e4a988} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:47522). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:15.789742 [ 6019 ] {ef99db14-b3c8-4d31-ae62-18201c394194} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 53, line 68) (in query: SELECT toDecimal64('4294967296', 0) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:15.867382 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:15.940947 [ 6019 ] {238c54d3-ccdd-468b-85f6-ba58e522d30f} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 4) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 55, line 70) (in query: SELECT toDecimal64('4294967296', 4) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:15.943485 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 4) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:16.050380 [ 6019 ] {3bf8f71f-f339-4be1-8793-7d5208144f06} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 57, line 73) (in query: SELECT toDecimal128('65536', 0) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:16.053448 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:16.215163 [ 6019 ] {604463b7-d0d9-4d6c-8659-2644c30dddbe} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 10) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 59, line 75) (in query: SELECT toDecimal128('65536', 10) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:16.219309 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 10) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:16.246277 [ 4170 ] {11588b89-3791-41dc-8be2-3beb58fef155} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=0): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 6255370, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 511ad52c3adacfab568c8ba3febe8f86828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 95 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45476) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:16.291407 [ 4170 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=0): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 6255370, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 511ad52c3adacfab568c8ba3febe8f86828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 95 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:16.317819 [ 6070 ] {af845508-12b3-4efd-af36-0476a9b9a169} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=0): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 6255370, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 511ad52c3adacfab568c8ba3febe8f86828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 95 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54932) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:10:16.340963 [ 6070 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.10:9000. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=0): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 6255370, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 511ad52c3adacfab568c8ba3febe8f86828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 95 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:16.391328 [ 6019 ] {1463bebb-8b2f-4201-b5d8-abb41793b3de} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 61, line 77) (in query: SELECT toDecimal64('65536', 0) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:16.393973 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:16.472666 [ 6019 ] {0740a608-986f-475b-8084-4daabddc54ac} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 4) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 63, line 79) (in query: SELECT toDecimal64('65536', 4) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:16.475364 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 4) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:16.671246 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_53_58_1}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001f85446d 4. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000001f84c969 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:146: CurrentMemoryTracker::injectFault() @ 0x000000001f62af1f 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:269: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000001f8efcd5 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a57ca6b 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a57949e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:17.174146 [ 10149 ] {ded56108-6539-422b-800a-0b544697bdce} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: while executing 'FUNCTION CAST(__table1.d :: 2, 'Date'_String :: 1) -> CAST(__table1.d, 'Date'_String) Date : 0'. (CANNOT_PARSE_DATE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54826) (comment: 03034_dynamic_conversions.sql) (query 28, line 33) (in query: select d::Date from test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000001f9b1f3b 5. ./src/IO/ReadHelpers.h:829: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000027090bb3 6. ./src/IO/ReadHelpers.h:850: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002cc2815a 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cc016e7 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c9483e3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9888dd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c987822 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 17. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x000000002c33d1ea 18. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x000000002c33cc8e 19. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008eed6b1 20. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c33cba9 21. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 23. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 24. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 25. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 26. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 27. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 28. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 2025.11.13 09:10:17.185867 [ 10149 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: while executing 'FUNCTION CAST(__table1.d :: 2, 'Date'_String :: 1) -> CAST(__table1.d, 'Date'_String) Date : 0'. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000001f9b1f3b 5. ./src/IO/ReadHelpers.h:829: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000027090bb3 6. ./src/IO/ReadHelpers.h:850: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002cc2815a 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cc016e7 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c9483e3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9888dd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c987822 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 16. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 17. DB::detail::FunctionCast::createDynamicToColumnWrapper(std::shared_ptr const&) const::'lambda'(std::vector>&, std::shared_ptr const&)::operator()(std::vector>&, std::shared_ptr const&) const @ 0x000000002c33d1ea 18. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&), COW::immutable_ptr (std::vector>&, std::shared_ptr)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr&&) @ 0x000000002c33cc8e 19. DB::detail::ConvertImplFromDynamicToColumn::execute(std::vector> const&, std::shared_ptr const&, unsigned long, std::function::immutable_ptr (std::vector>&, std::shared_ptr)> const&) @ 0x0000000008eed6b1 20. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c33cba9 21. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 23. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 24. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 25. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 26. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 27. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 28. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:17.201536 [ 10211 ] {be9c180b-f386-42ad-b2d0-e7bd041dbc41} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=3): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 4872604, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 3e41ab9b5155dc7a0272b862b5197309828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 74 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60500) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:10:17.225438 [ 5639 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33532, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:17.225801 [ 5639 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33532, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:17.231717 [ 6079 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50518, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:17.232030 [ 6079 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50518, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:17.330873 [ 10211 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=3): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/data.bin (position: 4872604, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 3e41ab9b5155dc7a0272b862b5197309828b80000000800000): (while reading column a): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_9_9_0/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 74 with max_rows_to_read = 65536): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:17.475139 [ 6092 ] {3d367eed-1061-46b6-b8a4-10b586a816c5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48594) (comment: 03034_dynamic_conversions.sql) (in query: DROP DATABASE IF EXISTS test_anatfxl7 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:17.477517 [ 6092 ] {3d367eed-1061-46b6-b8a4-10b586a816c5} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:18.399636 [ 6028 ] {fbb009cb-8ea7-4155-8ed9-a227daab8273} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 393216, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: db2c0255b9c2e10b78e6b2d3b74e0b4e820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 0 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60514) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 2025.11.13 09:10:18.514957 [ 4759 ] {bd98a925-87f0-4d38-acf3-97d27eade61a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42312) (comment: 03279_join_choose_build_table.sql) (query 20, line 85) (in query: SELECT if(ProfileEvents['JoinBuildTableRowCount'] BETWEEN 100 AND 2000, 'ok', 'fail: ' || toString(ProfileEvents['JoinBuildTableRowCount'])), if(ProfileEvents['JoinProbeTableRowCount'] BETWEEN 90_000 AND 110_000, 'ok', 'fail: ' || toString(ProfileEvents['JoinProbeTableRowCount'])), if(ProfileEvents['JoinResultRowCount'] == 1000, 'ok', 'fail: ' || toString(ProfileEvents['JoinResultRowCount'])), Settings['query_plan_join_swap_table'], FROM system.query_log WHERE type = 'QueryFinish' AND event_date >= yesterday() AND query_kind = 'Select' AND current_database = currentDatabase() AND query like '%sales, products%' AND log_comment = '03279_join_choose_build_table_idx' ORDER BY event_time DESC LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:18.551468 [ 4759 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:18.567539 [ 10610 ] {7a0ccc78-47a1-4416-a497-3dedc60a4bc6} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:50530). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:18.678265 [ 6028 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 393216, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: db2c0255b9c2e10b78e6b2d3b74e0b4e820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 0 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:18.731972 [ 4390 ] {adc9b6e2-a657-42c0-b1bc-c7428e521a3b} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:59796). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:18.868831 [ 6019 ] {efa80a4d-7393-479f-92a9-b5e7f9ece438} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 67, line 84) (in query: SELECT toInt64('2147483649') AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42eff7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c10e 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce764d8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5152f 8. ./src/Core/callOnTypeIndex.h:262: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ee19 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:18.871870 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42eff7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c10e 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce764d8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5152f 8. ./src/Core/callOnTypeIndex.h:262: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ee19 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:18.890456 [ 6019 ] {f7034b4a-87ca-42ec-b35c-31be14386b88} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: -2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('-2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 68, line 85) (in query: SELECT toInt64('-2147483649') AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42eff7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c10e 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce764d8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5152f 8. ./src/Core/callOnTypeIndex.h:262: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ee19 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:18.893609 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: -2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('-2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42eff7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c10e 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce764d8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5152f 8. ./src/Core/callOnTypeIndex.h:262: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ee19 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:20.621685 [ 5295 ] {edf518e3-7d5e-4252-afef-fab05663c47e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60586) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:20.625810 [ 10627 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38290, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:20.626137 [ 10627 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38290, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:20.640273 [ 4170 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50538, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:20.640551 [ 4170 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50538, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:20.708329 [ 5295 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:20.727144 [ 10699 ] {eac7a178-63a5-4e7a-8085-625fe095fd26} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 24481189, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: d739b40e68541531ed10e78e086ea0c3820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 720 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59808) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() AS `count()` FROM `test_9`.`t_index_hypothesis` AS `__table1` WHERE `__table1`.`a` = `__table1`.`b`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 2025.11.13 09:10:20.780436 [ 10699 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 24481189, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: d739b40e68541531ed10e78e086ea0c3820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 720 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:21.321661 [ 10609 ] {cdc29d73-ccb9-438f-9ec0-51923e08df25} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 24481189, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: d739b40e68541531ed10e78e086ea0c3820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 720 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60550) (comment: 02150_index_hypothesis_race_long.sh) (query 1, line 1) (in query: SELECT count() FROM t_index_hypothesis WHERE a = b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:10:21.372141 [ 10609 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=5): While reading or decompressing /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/b.bin (position: 24481189, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: d739b40e68541531ed10e78e086ea0c3820b01010000000100): (while reading column b): (while reading from part /var/lib/clickhouse/store/e8a/e8aa75ec-ed5b-4552-9157-be5cabb5ce97/all_1_6_1/ in table test_9.t_index_hypothesis (e8aa75ec-ed5b-4552-9157-be5cabb5ce97) located on disk default of type local, from mark 720 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4ec7 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:21.596845 [ 6078 ] {b611adef-957f-4f99-b6bf-860b2706562e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43420) (comment: 01010_partial_merge_join.sql) (in query: DROP DATABASE IF EXISTS test_91dw77db SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:21.606250 [ 6078 ] {b611adef-957f-4f99-b6bf-860b2706562e} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:21.638647 [ 6028 ] {80aa0b61-2cf5-4a02-922f-70a9a0b38829} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54232) (comment: 01010_partial_merge_join.sql) (in query: DROP DATABASE IF EXISTS test_91dw77db SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:21.640892 [ 6028 ] {80aa0b61-2cf5-4a02-922f-70a9a0b38829} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:22.068756 [ 6019 ] {cc0cb515-5435-4ba3-8645-61edc80586b7} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toUInt64('2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 69, line 86) (in query: SELECT toUInt64('2147483649') AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42fef3 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c224 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce69ed8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce4c96f 8. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ed83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:22.074326 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toUInt64('2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42fef3 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c224 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce69ed8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce4c96f 8. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ed83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:22.154621 [ 6079 ] {b80a2605-a107-4faa-bf1e-9d137e827463} executeQuery: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60606) (comment: 03275_block_number_mutation.sql) (query 10, line 15) (in query: DETACH TABLE t_block_number_delete;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d91d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:22.160871 [ 6079 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d91d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:24.036075 [ 5295 ] {ed7122f6-0b4f-4ecd-85e4-9a7c32a3053e} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST(NULL, 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33962) (comment: 02797_range_nullable.sql) (query 9, line 9) (in query: SELECT range(Null::Nullable(UInt64), 10::Nullable(UInt64), 2::Nullable(UInt64));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001f55e9c3 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f555195 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:10:24.039727 [ 5295 ] {} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST(NULL, 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001f55e9c3 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f555195 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:10:24.286541 [ 6019 ] {f7998d4f-714d-43af-b2e3-07f76c0fd028} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 9223372036854775809 is not in range (-9223372036854775808, 9223372036854775807): In scope SELECT toUInt64('9223372036854775809') AS x, toDecimal64(x, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 71, line 89) (in query: SELECT toUInt64('9223372036854775809') AS x, toDecimal64(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f434110 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45d264 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ceba301 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce9cc0f 8. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f7e3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:24.289288 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 9223372036854775809 is not in range (-9223372036854775808, 9223372036854775807): In scope SELECT toUInt64('9223372036854775809') AS x, toDecimal64(x, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f434110 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45d264 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ceba301 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce9cc0f 8. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f7e3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:24.733004 [ 10448 ] {3e093c7d-4b6e-47aa-9f52-cbb23b88cb78} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54760) (in query: select distinct sleep(.1),name from generateRandom('name String',1,1000,2) limit 100009 format TSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b71447d 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b22527f 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:10:25.242649 [ 5295 ] {12697726-6c03-4878-bd7f-5e409667bf1e} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33962) (comment: 02797_range_nullable.sql) (query 10, line 10) (in query: SELECT range(0::Nullable(UInt64), Null::Nullable(UInt64), 2::Nullable(UInt64));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001f55e9c3 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f555449 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:10:25.266188 [ 5295 ] {} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)'), CAST('2', 'Nullable(UInt64)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001f55e9c3 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f555449 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:10:25.281503 [ 10448 ] {3e093c7d-4b6e-47aa-9f52-cbb23b88cb78} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b71447d 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b22527f 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c833c 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:25.801347 [ 6019 ] {61c8bee6-0bc6-47d9-b1bb-4962df6d8adb} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal32(0, rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 72, line 91) (in query: SELECT toDecimal32(0, rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9adcbf 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ce49cfd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9ace1c 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9ad5fe 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:10:25.804081 [ 6019 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal32(0, rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9adcbf 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ce49cfd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9ace1c 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9ad5fe 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:10:26.697227 [ 5295 ] {e3cf3bfe-e089-4f37-bd51-0420183a510a} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)')). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33962) (comment: 02797_range_nullable.sql) (query 11, line 11) (in query: SELECT range(0::Nullable(UInt64), 10::Nullable(UInt64), Null::Nullable(UInt64));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001f55e9c3 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5557d4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:10:26.699925 [ 5295 ] {} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Nullable(UInt64) of argument of function range: In scope SELECT range(CAST('0', 'Nullable(UInt64)'), CAST('10', 'Nullable(UInt64)'), CAST(NULL, 'Nullable(UInt64)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001f55e9c3 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f5557d4 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:10:27.242244 [ 6019 ] {577c23de-745e-4eb2-a759-1613c9479c86} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal64(0, rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 73, line 92) (in query: SELECT toDecimal64(0, rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9b179f 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ce99f9d 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9b08fc 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9b10de 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:10:27.245469 [ 6019 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal64(0, rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9b179f 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ce99f9d 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9b08fc 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9b10de 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:10:27.618856 [ 5295 ] {213fbe41-f901-4154-9fe2-16c8eee983f2} executeQuery: Code: 36. DB::Exception: Illegal (null) value column Const(Nullable(UInt8)) of argument of function range. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33962) (comment: 02797_range_nullable.sql) (query 12, line 12) (in query: SELECT range(Null::Nullable(UInt8), materialize(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001f55e9c3 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f555195 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:10:27.621351 [ 5295 ] {} TCPHandler: Code: 36. DB::Exception: Illegal (null) value column Const(Nullable(UInt8)) of argument of function range. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnWithTypeAndName const&)::operator()(DB::ColumnWithTypeAndName const&) const @ 0x000000001f55e9c3 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f555195 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 14. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 16. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:10:28.715897 [ 6028 ] {e87dea68-1f73-4dbf-b996-cf38a321b9f6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34130) (comment: 03221_mutation_analyzer_skip_part.sh) (query 1, line 1) (in query: SELECT count() FROM system.part_log WHERE database = currentDatabase() AND table = 't_mutate_skip_part' AND event_type = 'MutatePart'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:10:28.723379 [ 6028 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:29.984290 [ 6019 ] {2bb2a9e6-5190-4391-b1ac-d676f5b17751} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal128(0, rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 74, line 93) (in query: SELECT toDecimal128(0, rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9b527f 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ceea8bd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9b43dc 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9b4bbe 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:10:29.986952 [ 6019 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal128(0, rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9b527f 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ceea8bd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9b43dc 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9b4bbe 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:10:31.774449 [ 4529 ] {9e83caad-5499-4875-bd52-c748e1ae3ce3} executeQuery: Code: 44. DB::Exception: Function 'like' doesn't support search with non-constant needles in constant haystack. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34120) (comment: 03278_enum_string_functions.sql) (query 33, line 41) (in query: SELECT CAST('a', 'Enum(\'a\' = 1)') LIKE randomString(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000146f782f 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 14. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:10:31.777436 [ 4529 ] {} TCPHandler: Code: 44. DB::Exception: Function 'like' doesn't support search with non-constant needles in constant haystack. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000146f782f 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 14. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:10:31.883881 [ 4529 ] {ecb9541c-03da-43e8-a650-fca4f89d0ed5} executeQuery: Code: 44. DB::Exception: Function 'like' doesn't support search with non-constant needles in constant haystack. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34120) (comment: 03278_enum_string_functions.sql) (query 35, line 44) (in query: SELECT CAST('a', 'Enum16(\'a\' = 1)') LIKE randomString(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000146f782f 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 14. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:10:31.888683 [ 4529 ] {} TCPHandler: Code: 44. DB::Exception: Function 'like' doesn't support search with non-constant needles in constant haystack. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000146f782f 4. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 12. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 14. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:10:32.595791 [ 6019 ] {782e3d3e-0fb5-4ab2-ac4b-7e343b006364} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal32(1 / 0, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 75, line 95) (in query: SELECT toDecimal32(1/0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:32.598202 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal32(1 / 0, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:33.018467 [ 8203 ] {303d9dda-d755-4ffb-b382-f39a94887477} ExternalDictionariesLoader: Could not load external dictionary '4b7e41bc-9480-434d-93e7-a01effeaabb3', next update is scheduled at 2025-11-13 09:10:35: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=0): while reading column id at /var/lib/clickhouse/store/529/529dd05b-6bc6-47a8-aae9-a6615e848609/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000002003ea96 13. DB::ReadBuffer::next() @ 0x0000000008ef7cef 14. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x000000003dd2bc22 17. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x000000003dd2c20d 18. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e7667 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 20. ./build_docker/./src/Storages/StorageLog.cpp:269: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000038f3bc87 21. ./build_docker/./src/Storages/StorageLog.cpp:202: DB::LogSource::generate() @ 0x0000000038f39f9a 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:29: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x00000000272270c7 7. DB::HashedArrayDictionary<(DB::DictionaryKeyType)0, false>::loadData() @ 0x000000002733a341 8. DB::HashedArrayDictionary<(DB::DictionaryKeyType)0, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000027339114 9. DB::registerDictionaryArrayHashed(DB::DictionaryFactory&)::$_2::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType) const @ 0x00000000273374b1 10. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002733515b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 12. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 13. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 14. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 15. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000328b751d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1378: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000328b7e99 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000328a36d8 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000910a67a 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000910026f 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:33.022500 [ 6023 ] {303d9dda-d755-4ffb-b382-f39a94887477} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=0): while reading column id at /var/lib/clickhouse/store/529/529dd05b-6bc6-47a8-aae9-a6615e848609/: While executing Log: while executing 'FUNCTION dictGet('hashed_array_dictionary_simple_key_simple_attributes'_String : 1, 'value_first'_String :: 2, __table1.number : 4) -> dictGet('hashed_array_dictionary_simple_key_simple_attributes'_String, 'value_first'_String, __table1.number) String : 0'. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33988) (comment: 02098_hashed_array_dictionary_simple_key.gen.sql) (query 11, line 30) (in query: SELECT dictGet('hashed_array_dictionary_simple_key_simple_attributes', 'value_first', number) as value_first, dictGet('hashed_array_dictionary_simple_key_simple_attributes', 'value_second', number) as value_second FROM system.numbers LIMIT 3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000002003ea96 13. DB::ReadBuffer::next() @ 0x0000000008ef7cef 14. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x000000003dd2bc22 17. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x000000003dd2c20d 18. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e7667 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 20. ./build_docker/./src/Storages/StorageLog.cpp:269: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000038f3bc87 21. ./build_docker/./src/Storages/StorageLog.cpp:202: DB::LogSource::generate() @ 0x0000000038f39f9a 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:10:33.047301 [ 6023 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=0): while reading column id at /var/lib/clickhouse/store/529/529dd05b-6bc6-47a8-aae9-a6615e848609/: While executing Log: while executing 'FUNCTION dictGet('hashed_array_dictionary_simple_key_simple_attributes'_String : 1, 'value_first'_String :: 2, __table1.number : 4) -> dictGet('hashed_array_dictionary_simple_key_simple_attributes'_String, 'value_first'_String, __table1.number) String : 0'. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000002003ea96 13. DB::ReadBuffer::next() @ 0x0000000008ef7cef 14. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 15. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:209: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c4fe 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x000000003dd2bc22 17. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x000000003dd2c20d 18. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e7667 19. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 20. ./build_docker/./src/Storages/StorageLog.cpp:269: DB::LogSource::readData(DB::NameAndTypePair const&, COW::immutable_ptr&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000038f3bc87 21. ./build_docker/./src/Storages/StorageLog.cpp:202: DB::LogSource::generate() @ 0x0000000038f39f9a 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:29: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x00000000272270c7 7. DB::HashedArrayDictionary<(DB::DictionaryKeyType)0, false>::loadData() @ 0x000000002733a341 8. DB::HashedArrayDictionary<(DB::DictionaryKeyType)0, false>::HashedArrayDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedArrayDictionaryStorageConfiguration const&, std::shared_ptr) @ 0x0000000027339114 9. DB::registerDictionaryArrayHashed(DB::DictionaryFactory&)::$_2::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType) const @ 0x00000000273374b1 10. std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002733515b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 12. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 13. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 14. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 15. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000328b751d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1378: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000328b7e99 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000328a36d8 10. DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000910a67a 11. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000910026f 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 16. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 18. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:33.491119 [ 6078 ] {3413e173-e1a4-4f56-9494-bbfa08e203ab} executeQuery: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION in(tuple(__table1.s, __table1.d, __table1.s) :: 5, __set_4042668501132216577_10822701807680875245 :: 2) -> in(tuple(__table1.s, __table1.d, __table1.s), __set_4042668501132216577_10822701807680875245) UInt8 : 1'. (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48270) (comment: 00981_in_subquery_with_tuple.sh) (query 1, line 1) (in query: SELECT * FROM bug WHERE (s, d, s) IN (SELECT s, max(d) FROM bug GROUP BY s)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000008e2d76d 4. ./build_docker/./src/Interpreters/Set.cpp:602: DB::Set::execute(std::vector> const&, bool) const @ 0x000000003304c344 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x00000000116e9b95 6. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000116e7bd0 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:156: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003bb1b7a6 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:140: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003bb1b304 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:10:33.498824 [ 6078 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 2 at right.: while executing 'FUNCTION in(tuple(__table1.s, __table1.d, __table1.s) :: 5, __set_4042668501132216577_10822701807680875245 :: 2) -> in(tuple(__table1.s, __table1.d, __table1.s), __set_4042668501132216577_10822701807680875245) UInt8 : 1'. (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000008e2d76d 4. ./build_docker/./src/Interpreters/Set.cpp:602: DB::Set::execute(std::vector> const&, bool) const @ 0x000000003304c344 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x00000000116e9b95 6. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000116e7bd0 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:156: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003bb1b7a6 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:140: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003bb1b304 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:34.354408 [ 4389 ] {e830e0cc-df1c-4a3c-a69d-50bcef92f258} executeQuery: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 3 at right.: while executing 'FUNCTION in(tuple(__table1.s, __table1.d) :: 5, __set_16086011669591868969_4859334879252798401 :: 2) -> in(tuple(__table1.s, __table1.d), __set_16086011669591868969_4859334879252798401) UInt8 : 0'. (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48364) (comment: 00981_in_subquery_with_tuple.sh) (query 1, line 1) (in query: SELECT * FROM bug WHERE (s, d) IN (SELECT s, max(d), s FROM bug GROUP BY s)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000008e2d76d 4. ./build_docker/./src/Interpreters/Set.cpp:602: DB::Set::execute(std::vector> const&, bool) const @ 0x000000003304c344 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x00000000116e9b95 6. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000116e7bd0 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:156: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003bb1b7a6 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:140: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003bb1b304 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:10:34.359885 [ 4389 ] {} TCPHandler: Code: 20. DB::Exception: Number of columns in section IN doesn't match. 1 at left, 3 at right.: while executing 'FUNCTION in(tuple(__table1.s, __table1.d) :: 5, __set_16086011669591868969_4859334879252798401 :: 2) -> in(tuple(__table1.s, __table1.d), __set_16086011669591868969_4859334879252798401) UInt8 : 0'. (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x0000000008e2d76d 4. ./build_docker/./src/Interpreters/Set.cpp:602: DB::Set::execute(std::vector> const&, bool) const @ 0x000000003304c344 5. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x00000000116e9b95 6. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000116e7bd0 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:156: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003bb1b7a6 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:140: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003bb1b304 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:35.379972 [ 6019 ] {4c3f37f9-ecbb-4089-b7f3-fdada5247a14} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal64(1 / 0, 1). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 76, line 96) (in query: SELECT toDecimal64(1/0, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:35.383332 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal64(1 / 0, 1). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:36.093040 [ 4389 ] {6947a1fb-198f-49b3-ae45-151e870959ba} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48434) (comment: 02661_read_from_archive_7z.sh) (query 1, line 1) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/02661_read_from_archive_test_5_7z_archive1.7z :: 02661_read_from_archive_test_5_7z_data1.csv') ORDER BY 1, 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:10:36.102889 [ 4389 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:38.259796 [ 6019 ] {8fc8ba6e-122d-497c-a537-441a63091aa6} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal128(0 / 0, 2). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 77, line 97) (in query: SELECT toDecimal128(0/0, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:38.262799 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal128(0 / 0, 2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:39.727682 [ 10627 ] {c5b9e7ac-f758-4f7c-989a-7a800bd5687a} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n4, 0\n': (at row 1) : Row 1: Column 0, name: a, type: UInt64, parsed text: "3" Column 1, name: b, type: UInt64, parsed text: " 0" ERROR: Line feed found where delimiter (,) is expected. It's like your file has less columns than expected. And if your file has the right number of columns, maybe it has unescaped quotes in values. : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45006) (comment: 03279_insert_sparse_parsing_error.sh) (in query: INSERT INTO t_insert_sparse_columns FORMAT CSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b4ec2b8 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43287e 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:10:39.731888 [ 10627 ] {c5b9e7ac-f758-4f7c-989a-7a800bd5687a} DynamicQueryHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n4, 0\n': (at row 1) : Row 1: Column 0, name: a, type: UInt64, parsed text: "3" Column 1, name: b, type: UInt64, parsed text: " 0" ERROR: Line feed found where delimiter (,) is expected. It's like your file has less columns than expected. And if your file has the right number of columns, maybe it has unescaped quotes in values. : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b4ec2b8 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43287e 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:39.999961 [ 6019 ] {7866d619-6479-4039-8a0e-03ff2e9c03b4} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(9, 0)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 78, line 98) (in query: SELECT CAST(1/0, 'Decimal(9, 0)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c69d1b8 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c677119 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c66c45f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c66b5a4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:40.012182 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(9, 0)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c69d1b8 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c677119 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c66c45f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c66b5a4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:40.565545 [ 10448 ] {84c459b2-d8f4-40e8-bd77-f3f7f7963b3f} executeQuery: Code: 36. DB::Exception: Explicitly specified value of minimum unit argument (hours) for function formatReadableTimeDelta must not be greater than maximum unit value (seconds).: In scope SELECT formatReadableTimeDelta(1.1, 'seconds', 'hours'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48620) (comment: 02887_format_readable_timedelta_subseconds.sql) (query 3, line 15) (in query: -- Check exception is thrown SELECT formatReadableTimeDelta(1.1, 'seconds', 'hours');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&, String, std::basic_string_view>&>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity>&>::type>, std::basic_string_view>&, String&&, std::basic_string_view>&) @ 0x000000000ee5c0d7 4. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee58e1e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:10:40.573487 [ 10448 ] {} TCPHandler: Code: 36. DB::Exception: Explicitly specified value of minimum unit argument (hours) for function formatReadableTimeDelta must not be greater than maximum unit value (seconds).: In scope SELECT formatReadableTimeDelta(1.1, 'seconds', 'hours'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&, String, std::basic_string_view>&>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity>&>::type>, std::basic_string_view>&, String&&, std::basic_string_view>&) @ 0x000000000ee5c0d7 4. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee58e1e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:10:40.883023 [ 4759 ] {a2dd3135-8485-4ec8-83cf-8e377057a260} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60434) (comment: 03279_insert_sparse_parsing_error.sh) (in query: DROP DATABASE IF EXISTS test_vmpgy68f SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:40.885571 [ 4759 ] {a2dd3135-8485-4ec8-83cf-8e377057a260} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:41.539711 [ 6019 ] {540037fd-d6cc-472d-9f1c-a817c3b0f263} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(18, 1)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 79, line 99) (in query: SELECT CAST(1/0, 'Decimal(18, 1)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c6e15e1 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c6baf79 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6b02bf 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6af404 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:41.543090 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(18, 1)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c6e15e1 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c6baf79 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6b02bf 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6af404 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:41.730173 [ 4714 ] {dc1a5768-384c-4193-8840-240ac8f553e6} executeQuery: Code: 80. DB::Exception: Query from view test_b6rkqk5l.view_no_nulls returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48612) (comment: 01866_view_persist_settings.sql) (query 14, line 37) (in query: SELECT * FROM view_no_nulls;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageView.cpp:203: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038eabc25 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:41.733804 [ 4714 ] {} TCPHandler: Code: 80. DB::Exception: Query from view test_b6rkqk5l.view_no_nulls returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageView.cpp:203: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038eabc25 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:43.112928 [ 4714 ] {b7ec08a8-db26-41ff-9970-f4e308411172} executeQuery: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48612) (comment: 01866_view_persist_settings.sql) (query 31, line 58) (in query: DETACH TABLE view_no_nulls;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d91d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:43.116013 [ 4714 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d91d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:43.303320 [ 6019 ] {3ba80815-d80f-4984-8d3f-fede3fb66f6e} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(38, 2)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 80, line 100) (in query: SELECT CAST(1/0, 'Decimal(38, 2)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c725a4d 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>>(T const&) const @ 0x000000002c6ff639 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6f497f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6f3ac4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:43.305879 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(38, 2)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c725a4d 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>>(T const&) const @ 0x000000002c6ff639 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6f497f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6f3ac4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:43.321144 [ 6019 ] {8267e9ec-dc80-4b93-8ff9-1da729d2693a} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(9, 3)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 81, line 101) (in query: SELECT CAST(0/0, 'Decimal(9, 3)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c69d1b8 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c677119 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c66c45f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c66b5a4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:43.323603 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(9, 3)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c69d1b8 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c677119 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c66c45f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c66b5a4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:43.401194 [ 6019 ] {5d6f4470-038f-47af-b8fe-19247aca8c93} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(18, 4)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 82, line 102) (in query: SELECT CAST(0/0, 'Decimal(18, 4)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c6e15e1 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c6baf79 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6b02bf 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6af404 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:43.404927 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(18, 4)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c6e15e1 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c6baf79 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6b02bf 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6af404 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:43.424951 [ 6019 ] {0b6de8ab-94e2-46ee-bd7f-5b5a8946efe2} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(38, 5)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 83, line 103) (in query: SELECT CAST(0/0, 'Decimal(38, 5)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c725a4d 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>>(T const&) const @ 0x000000002c6ff639 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6f497f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6f3ac4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:43.428893 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(38, 5)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c725a4d 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>>(T const&) const @ 0x000000002c6ff639 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6f497f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6f3ac4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:10:43.855730 [ 10627 ] {340540af-83cb-4338-8c86-1e65540529d9} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60456) (comment: 01866_view_persist_settings.sql) (in query: DROP DATABASE IF EXISTS test_b6rkqk5l SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:43.858502 [ 10627 ] {340540af-83cb-4338-8c86-1e65540529d9} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:44.144980 [ 10181 ] {96fb7293-fdb7-41eb-a181-60783ebf0395} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57522) (query 1, line 1) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038521118 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.151682 [ 10181 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038521118 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.619443 [ 6006 ] {a6513a9e-8fa4-433d-aa3e-10ba9c8c1909} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:9da4494f-de4c-4eac-b7b5-616582827794'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60470) (comment: 01509_parallel_quorum_insert_no_replicas_long.sql) (in query: CREATE DATABASE IF NOT EXISTS test_f52fmsi6 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.627543 [ 6006 ] {a6513a9e-8fa4-433d-aa3e-10ba9c8c1909} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:9da4494f-de4c-4eac-b7b5-616582827794'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:44.678314 [ 4389 ] {e635de76-6daf-4163-b3f7-b9dea92299a3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:16530ba9-4d9d-48b3-be35-32a4559fa6eb'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60472) (comment: 01324_insert_tsv_raw.sql) (in query: CREATE DATABASE IF NOT EXISTS test_b56g6bji ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.681073 [ 4389 ] {e635de76-6daf-4163-b3f7-b9dea92299a3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:16530ba9-4d9d-48b3-be35-32a4559fa6eb'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:44.737001 [ 6006 ] {43fed17c-732b-4493-bd1e-cd449b936b3a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:860b8fde-07af-4f69-aab0-302ca6e1e489'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60488) (comment: 00379_system_processes_port.sh) (in query: CREATE DATABASE IF NOT EXISTS test_c438so16 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.740426 [ 6006 ] {43fed17c-732b-4493-bd1e-cd449b936b3a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:860b8fde-07af-4f69-aab0-302ca6e1e489'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:44.769332 [ 6079 ] {3cc2df6e-5f2d-4116-8404-a7c00ff5c63b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:4891327c-fe18-45e4-b2f5-ba33fe50fc9a'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60500) (comment: 00933_ttl_simple.sql) (in query: CREATE DATABASE IF NOT EXISTS test_c6r6ezw7 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.773052 [ 6079 ] {3cc2df6e-5f2d-4116-8404-a7c00ff5c63b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:4891327c-fe18-45e4-b2f5-ba33fe50fc9a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:44.801463 [ 6006 ] {b9fad108-1abf-4b91-83aa-81f541a8213c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:f8d2947a-9b59-49b3-ae4d-6c7e25c31054'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60516) (comment: 03008_azure_plain_rewritable.sh) (in query: CREATE DATABASE IF NOT EXISTS test_2sw0xrei ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.803933 [ 6006 ] {b9fad108-1abf-4b91-83aa-81f541a8213c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:f8d2947a-9b59-49b3-ae4d-6c7e25c31054'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:44.831353 [ 6079 ] {c18e452d-328c-48f8-af8f-db04e7affae0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:87af34f5-a301-4d52-8c3c-028cb489fd4d'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60518) (comment: 00165_transform_non_const_default.sql) (in query: CREATE DATABASE IF NOT EXISTS test_bakffoxy ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.834099 [ 6079 ] {c18e452d-328c-48f8-af8f-db04e7affae0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:87af34f5-a301-4d52-8c3c-028cb489fd4d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:44.858173 [ 6006 ] {0cb62381-f90c-4c18-9aab-4381d88094f6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:cc5defa5-3abf-4811-9f30-4356c089df1a'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60522) (comment: 00217_shard_global_subquery_columns_with_same_name.sql) (in query: CREATE DATABASE IF NOT EXISTS test_yzpprsss ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.860839 [ 6006 ] {0cb62381-f90c-4c18-9aab-4381d88094f6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:cc5defa5-3abf-4811-9f30-4356c089df1a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:44.913086 [ 6079 ] {78d3e5b2-528c-421b-a885-527384d42e94} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:05771e92-428a-4972-91fe-af6b15889d4e'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60536) (comment: 01716_drop_rename_sign_column.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nnzi2fl8 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.915541 [ 6079 ] {78d3e5b2-528c-421b-a885-527384d42e94} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:05771e92-428a-4972-91fe-af6b15889d4e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:44.942599 [ 6028 ] {308881cc-818e-4cf9-99ca-070f0a75364e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:dd4c7f7a-b58e-4797-ac5a-b3a319e1d30f'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60546) (comment: 03218_materialize_msan.sql) (in query: CREATE DATABASE IF NOT EXISTS test_q3w4sdwb ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.945406 [ 6028 ] {308881cc-818e-4cf9-99ca-070f0a75364e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:dd4c7f7a-b58e-4797-ac5a-b3a319e1d30f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:44.969795 [ 6079 ] {3fc48ff9-2d5f-4067-a014-e506423b9e39} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:0c2d3bc4-f184-4450-8efe-ff881943ee04'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60554) (comment: 03251_parquet_page_v2_native_reader.sh) (in query: CREATE DATABASE IF NOT EXISTS test_9sdwchjv ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:44.972779 [ 6079 ] {3fc48ff9-2d5f-4067-a014-e506423b9e39} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:0c2d3bc4-f184-4450-8efe-ff881943ee04'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.013536 [ 6028 ] {5da25d8e-996f-4f81-97a2-f5caed83138c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:dad67ece-addb-4cdc-b3e9-501aae5b12ae'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60562) (comment: 00825_protobuf_format_skipped_column_in_nested.sh) (in query: CREATE DATABASE IF NOT EXISTS test_vdcgeggp ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.016102 [ 6028 ] {5da25d8e-996f-4f81-97a2-f5caed83138c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:dad67ece-addb-4cdc-b3e9-501aae5b12ae'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.056621 [ 6028 ] {cbf05f4a-bb9c-4af7-8e20-86011c5bff70} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:a815a9c1-0b93-4a6a-8adb-f8faf7a3efee'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60574) (comment: 01600_quota_by_forwarded_ip.sh) (in query: CREATE DATABASE IF NOT EXISTS test_p37oecw7 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.059232 [ 6028 ] {cbf05f4a-bb9c-4af7-8e20-86011c5bff70} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:a815a9c1-0b93-4a6a-8adb-f8faf7a3efee'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.093947 [ 4714 ] {70ec9354-6992-4e00-8544-80bf2207b29b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:6be6fe4a-4f44-46cc-9311-44e50bd0cd70'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60586) (comment: 00401_merge_and_stripelog.sql) (in query: CREATE DATABASE IF NOT EXISTS test_g88huq29 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.096821 [ 4714 ] {70ec9354-6992-4e00-8544-80bf2207b29b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:6be6fe4a-4f44-46cc-9311-44e50bd0cd70'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.128782 [ 6028 ] {4ba0c379-00ce-4910-9ccd-87adbe515f12} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:6e201660-2787-4c58-8326-e43d395192bc'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60588) (comment: 01456_modify_column_type_via_add_drop_update.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1wlyz6sf ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.131302 [ 6028 ] {4ba0c379-00ce-4910-9ccd-87adbe515f12} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:6e201660-2787-4c58-8326-e43d395192bc'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.182118 [ 6070 ] {e98e371f-93b0-44d4-81c0-53087b1f5b4c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:9bcc40b7-7e17-4333-adc2-ca721190beb1'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60590) (comment: 03094_one_thousand_joins.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pmuv9up8 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.184720 [ 6070 ] {e98e371f-93b0-44d4-81c0-53087b1f5b4c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:9bcc40b7-7e17-4333-adc2-ca721190beb1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.214417 [ 6070 ] {4bc96ca5-c710-48dd-89d1-ebb6f8e3f5b7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:591d2758-b488-4b20-8f8e-390eef4b05c6'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60596) (comment: 01071_force_optimize_skip_unused_shards.sql) (in query: CREATE DATABASE IF NOT EXISTS test_mvdww6ru ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.217043 [ 6070 ] {4bc96ca5-c710-48dd-89d1-ebb6f8e3f5b7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:591d2758-b488-4b20-8f8e-390eef4b05c6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.297791 [ 6070 ] {afa39ec6-9612-4b94-b15a-7bfbd72180e8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:310c81cd-1f21-4a38-b0f0-4ec479c699e3'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60610) (comment: 02046_low_cardinality_parallel_group_by.sh) (in query: CREATE DATABASE IF NOT EXISTS test_mo9wu477 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.300668 [ 6070 ] {afa39ec6-9612-4b94-b15a-7bfbd72180e8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:310c81cd-1f21-4a38-b0f0-4ec479c699e3'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.427999 [ 10609 ] {db7097df-3504-4801-9d1a-f6cef9e5e44e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:6f86a4a2-7242-4241-9043-426256ca447c'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60624) (comment: 01018_ddl_dictionaries_concurrent_requrests.sh) (in query: CREATE DATABASE IF NOT EXISTS test_vsvn8pn0 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.430575 [ 10609 ] {db7097df-3504-4801-9d1a-f6cef9e5e44e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:6f86a4a2-7242-4241-9043-426256ca447c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.470810 [ 10181 ] {a3b992fd-9bdf-45ef-81e9-f7c39de4734f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:26a2fade-ac46-4a93-a44f-a0a87e7163e8'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60632) (comment: 01946_test_wrong_host_name_access.sh) (in query: CREATE DATABASE IF NOT EXISTS test_2lorwhgw ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.473255 [ 10181 ] {a3b992fd-9bdf-45ef-81e9-f7c39de4734f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:26a2fade-ac46-4a93-a44f-a0a87e7163e8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.507532 [ 10609 ] {b0539a95-2a6a-4631-8d3d-a7042da328f9} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:615d3f70-c1e0-4238-a38d-18f1a99b13b9'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60648) (comment: 03279_database_backup_database_disk_engine.sql) (in query: CREATE DATABASE IF NOT EXISTS test_o93nap1a ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.509997 [ 10609 ] {b0539a95-2a6a-4631-8d3d-a7042da328f9} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:615d3f70-c1e0-4238-a38d-18f1a99b13b9'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.542563 [ 10181 ] {19d73907-c540-4eb6-ae52-87cc13c44675} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:98d75729-c8c2-4ad4-bdc0-dfba6ad1b87c'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60650) (comment: 02096_rename_atomic_hang.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ruunlmes ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.642373 [ 10181 ] {19d73907-c540-4eb6-ae52-87cc13c44675} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:98d75729-c8c2-4ad4-bdc0-dfba6ad1b87c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.677405 [ 6070 ] {09dd3222-f769-4a9f-9d7d-7b7e73ae59de} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:3e1deffa-7c24-4a7d-999b-970c142bdb77'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60660) (comment: 02723_parallelize_output_setting.sql) (in query: CREATE DATABASE IF NOT EXISTS test_jgiav80v ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.681554 [ 6070 ] {09dd3222-f769-4a9f-9d7d-7b7e73ae59de} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:3e1deffa-7c24-4a7d-999b-970c142bdb77'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.734054 [ 6070 ] {2904a33f-5d1a-4c1b-a0f7-065ef396cc26} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:d8018d24-8690-4600-970d-f4890e8ac208'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60662) (comment: 00152_insert_different_granularity.sql) (in query: CREATE DATABASE IF NOT EXISTS test_l14bkf3e ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.736450 [ 6070 ] {2904a33f-5d1a-4c1b-a0f7-065ef396cc26} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:d8018d24-8690-4600-970d-f4890e8ac208'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.764559 [ 6019 ] {e7c960ac-5a2d-426f-9e55-5b939a8fd602} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(10000.1, 6). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 84, line 105) (in query: select toDecimal32(10000.1, 6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:45.767684 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(10000.1, 6). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:45.818378 [ 10181 ] {e349f1b2-a9f8-4a96-afed-b928f24f6484} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:440929ce-72bc-40fe-842e-16355b8d7233'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60666) (comment: 00164_quantileBfloat16.sql) (in query: CREATE DATABASE IF NOT EXISTS test_5rk6jjwq ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.820818 [ 10181 ] {e349f1b2-a9f8-4a96-afed-b928f24f6484} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:440929ce-72bc-40fe-842e-16355b8d7233'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.840310 [ 6070 ] {8cfad456-331e-4f97-996d-8cf0879a6748} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:c33a15a8-f4f9-4bb3-9568-39f0ccfe0356'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60678) (comment: 02028_add_default_database_for_alterquery_on_cluster.sql) (in query: CREATE DATABASE IF NOT EXISTS test_636b6p6t ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.842811 [ 6070 ] {8cfad456-331e-4f97-996d-8cf0879a6748} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:c33a15a8-f4f9-4bb3-9568-39f0ccfe0356'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.871226 [ 10181 ] {816761d2-503d-4fb9-ba4a-d9489a41abb0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:caf360fc-6e52-4c1b-af8e-c3283313f168'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60694) (comment: 02182_json_each_row_schema_inference.sh) (in query: CREATE DATABASE IF NOT EXISTS test_p7f4ngm2 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.873682 [ 10181 ] {816761d2-503d-4fb9-ba4a-d9489a41abb0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:caf360fc-6e52-4c1b-af8e-c3283313f168'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.896342 [ 6070 ] {dc6a1645-f073-4962-9a00-182a6ebc41ad} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:c9a955a0-9bf7-45c9-8113-171437a3d16e'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60700) (comment: 03221_create_if_not_exists_setting.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ves2pyze ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.898749 [ 6070 ] {dc6a1645-f073-4962-9a00-182a6ebc41ad} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:c9a955a0-9bf7-45c9-8113-171437a3d16e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.918947 [ 10181 ] {fccc06a5-808a-4b5a-8737-7ff6a809f324} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:f57fc742-959e-4204-aa39-9408a3a6b01f'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60704) (comment: 00007_uniq.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lq6dkgyd ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:45.921456 [ 10181 ] {fccc06a5-808a-4b5a-8737-7ff6a809f324} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:f57fc742-959e-4204-aa39-9408a3a6b01f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:45.991342 [ 6070 ] {21359c5f-a8d5-4359-aacc-bf1ae28cc9ef} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:b8f731ff-3573-4125-b864-1bfd3978f618'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60708) (comment: 02179_dict_reload_on_cluster.sql) (in query: CREATE DATABASE IF NOT EXISTS test_jvp43sb0 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:46.003587 [ 6070 ] {21359c5f-a8d5-4359-aacc-bf1ae28cc9ef} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:b8f731ff-3573-4125-b864-1bfd3978f618'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:46.119582 [ 4759 ] {49deffa1-e794-4cf5-a92b-60599a6049cd} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:b32a90c9-ad1e-418d-b5f3-ad7711144183'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60710) (comment: 01275_parallel_mv.gen.sql) (in query: CREATE DATABASE IF NOT EXISTS test_6xk0re8w ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:46.122168 [ 4759 ] {49deffa1-e794-4cf5-a92b-60599a6049cd} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:b32a90c9-ad1e-418d-b5f3-ad7711144183'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:46.153183 [ 6005 ] {d047502a-925e-4154-9d15-c7e41d4be4af} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:29741a2e-acb4-49a8-863b-6cee889d9360'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60716) (comment: 01747_system_session_log_long.sh) (in query: CREATE DATABASE IF NOT EXISTS test_rf7ytpmm ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:46.155617 [ 6005 ] {d047502a-925e-4154-9d15-c7e41d4be4af} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:29741a2e-acb4-49a8-863b-6cee889d9360'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:46.177226 [ 4759 ] {72f7e68c-9096-4106-8000-ebba369f04cb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:d1a5438e-1d1c-45ca-acdd-573a88d76dd2'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60728) (comment: 00009_uniq_distributed.sql) (in query: CREATE DATABASE IF NOT EXISTS test_z4jj4v2a ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:46.179645 [ 4759 ] {72f7e68c-9096-4106-8000-ebba369f04cb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:d1a5438e-1d1c-45ca-acdd-573a88d76dd2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:46.199530 [ 6005 ] {01b137fe-af70-4c2f-be2d-d00f161732f3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:bd4ca62b-7065-49ab-82d8-651bc89b349c'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60738) (comment: 01164_alter_memory_database.sql) (in query: CREATE DATABASE IF NOT EXISTS test_bfhvijbc ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:46.202734 [ 6005 ] {01b137fe-af70-4c2f-be2d-d00f161732f3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:bd4ca62b-7065-49ab-82d8-651bc89b349c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:46.235636 [ 6006 ] {8c7aad33-dee4-4b1e-bfc9-dc94f32e7f7e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:64dbf461-fcb8-4dc8-91b0-70c872428f83'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60744) (comment: 01281_unsucceeded_insert_select_queries_counter.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ma4tjuhd ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:46.238140 [ 6006 ] {8c7aad33-dee4-4b1e-bfc9-dc94f32e7f7e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:64dbf461-fcb8-4dc8-91b0-70c872428f83'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:46.271405 [ 6079 ] {938a072b-61fe-4627-9a14-6763d18e505b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:d9a1d320-0877-4818-a3ba-e501e15ec119'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60746) (comment: 00182_simple_squashing_transform_bug.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3liluntg ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:46.326858 [ 6079 ] {938a072b-61fe-4627-9a14-6763d18e505b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:d9a1d320-0877-4818-a3ba-e501e15ec119'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:46.345901 [ 10149 ] {b86f8198-c862-468c-ad12-b97836b2581b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): (while reading prefix of column d): (while reading from part /var/lib/clickhouse/store/3a8/3a8447e9-cd6e-4abc-8acf-cdcf7878bac3/all_1_38_8/ in table test_e4cl9lpj.t (3a8447e9-cd6e-4abc-8acf-cdcf7878bac3) located on disk default of type local, from mark 0 with max_rows_to_read = 143): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48482) (comment: 03212_variant_dynamic_cast_or_default.sql) (query 59, line 94) (in query: select distinct toInt128OrDefault(d) as res from t order by res;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:376: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::NameAndTypePair const&, unsigned long, unsigned long, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::function)::$_1, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eef7c6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5f53f0 12. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6bfcf6 13. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7e7388 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 15. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:429: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6b672a 16. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:101: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f817ab1 17. ./build_docker/./src/DataTypes/Serializations/SerializationDynamic.cpp:247: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f5feae5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:378: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, unsigned long, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::function) @ 0x0000000039eec505 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:397: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>)::$_0::operator()() const @ 0x0000000039eee612 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::unordered_map, std::hash, std::equal_to, std::allocator>>> std::__function::__policy_invoker, std::hash, std::equal_to, std::allocator>>> ()>::__call_impl[abi:ne190107] (DB::NameAndTypePair const&)>)::$_0, std::unordered_map, std::hash, std::equal_to, std::allocator>>> ()>>(std::__function::__policy_storage const*) @ 0x0000000039eef964 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039ef67ce 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:420: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>) @ 0x0000000039eecc0a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:448: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsWithPrefetch(unsigned long, unsigned long, unsigned long, Priority) @ 0x0000000039ee5beb 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:113: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool, bool) @ 0x0000000039ee539b 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:153: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee789a 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 27. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 28. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 30. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c358f91 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 2025.11.13 09:10:46.353022 [ 6006 ] {2faa90e5-6c33-4e57-b995-e61acc3df0bb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:6b469a48-97af-4d39-824b-6810ac443ff6'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60756) (comment: 02892_orc_filter_pushdown.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ygbuzznl ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:46.355778 [ 10149 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=2): (while reading prefix of column d): (while reading from part /var/lib/clickhouse/store/3a8/3a8447e9-cd6e-4abc-8acf-cdcf7878bac3/all_1_38_8/ in table test_e4cl9lpj.t (3a8447e9-cd6e-4abc-8acf-cdcf7878bac3) located on disk default of type local, from mark 0 with max_rows_to_read = 143): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:376: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::NameAndTypePair const&, unsigned long, unsigned long, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::function)::$_1, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eef7c6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5f53f0 12. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6bfcf6 13. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7e7388 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 15. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:429: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6b672a 16. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:101: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f817ab1 17. ./build_docker/./src/DataTypes/Serializations/SerializationDynamic.cpp:247: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f5feae5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:378: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, unsigned long, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::function) @ 0x0000000039eec505 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:397: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>)::$_0::operator()() const @ 0x0000000039eee612 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::unordered_map, std::hash, std::equal_to, std::allocator>>> std::__function::__policy_invoker, std::hash, std::equal_to, std::allocator>>> ()>::__call_impl[abi:ne190107] (DB::NameAndTypePair const&)>)::$_0, std::unordered_map, std::hash, std::equal_to, std::allocator>>> ()>>(std::__function::__policy_storage const*) @ 0x0000000039eef964 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039ef67ce 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:420: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>) @ 0x0000000039eecc0a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:448: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsWithPrefetch(unsigned long, unsigned long, unsigned long, Priority) @ 0x0000000039ee5beb 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:113: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool, bool) @ 0x0000000039ee539b 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:153: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee789a 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 27. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 28. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 30. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c358f91 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:46.356960 [ 6006 ] {2faa90e5-6c33-4e57-b995-e61acc3df0bb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:6b469a48-97af-4d39-824b-6810ac443ff6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:46.384198 [ 6079 ] {d259bcc0-bb11-4c03-b847-9ecabcb80803} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:5f61220f-9b33-437d-876e-811713df0c89'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60758) (comment: 01493_storage_set_persistency.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ja5qfjz4 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:10:46.386744 [ 6079 ] {d259bcc0-bb11-4c03-b847-9ecabcb80803} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: 'd32b9e83770c:9000:6e96b0c2-2650-4854-b671-ee39dfa34f22', current host ID: 'd32b9e83770c:9000:5f61220f-9b33-437d-876e-811713df0c89'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:47.358289 [ 10170 ] {daed8a7d-be90-41e5-9443-cd1b733e9ceb} executeQuery: Code: 6. DB::Exception: Cannot parse string 'a' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION nullIn('a'_String :: 2, __set_2981896477676004330_13741191019392472059 :: 1) -> nullIn('a'_String, __set_2981896477676004330_13741191019392472059) UInt8 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57470) (comment: 01600_select_in_different_types.sql) (query 22, line 33) (in query: SELECT 'a' IN (SELECT 1) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002c3e737c 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator()>>(DB::DataTypeNumber const&) const @ 0x000000002c3be7de 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c3b80a4 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b7b24 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000033776679 14. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000033777d5c 15. ./build_docker/./src/Interpreters/Set.cpp:470: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000033049a99 16. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x00000000116fa395 17. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000116f83d0 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 23. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 24. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 25. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 2025.11.13 09:10:47.363405 [ 10170 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'a' as UInt8: syntax error at begin of string. Note: there are toUInt8OrZero and toUInt8OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION nullIn('a'_String :: 2, __set_2981896477676004330_13741191019392472059 :: 1) -> nullIn('a'_String, __set_2981896477676004330_13741191019392472059) UInt8 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002c3e737c 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator()>>(DB::DataTypeNumber const&) const @ 0x000000002c3be7de 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c3b80a4 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b7b24 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000033776679 14. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000033777d5c 15. ./build_docker/./src/Interpreters/Set.cpp:470: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000033049a99 16. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x00000000116fa395 17. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000116f83d0 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 23. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 24. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 25. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:47.633085 [ 4529 ] {ca6a48d5-e713-4378-b766-d1f8a4e7d210} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:57518). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e7596 8. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:314: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5ae808 9. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 10. ./build_docker/./src/Formats/NativeWriter.cpp:78: DB::NativeWriter::write(DB::Block const&) @ 0x000000003b0d630f 11. ./build_docker/./src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7dc0 12. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 13. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:47.786847 [ 4529 ] {ca6a48d5-e713-4378-b766-d1f8a4e7d210} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:57518). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57518) (comment: 02003_memory_limit_in_client.sh) (query 1, line 1) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e7596 8. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:314: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5ae808 9. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 10. ./build_docker/./src/Formats/NativeWriter.cpp:78: DB::NativeWriter::write(DB::Block const&) @ 0x000000003b0d630f 11. ./build_docker/./src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7dc0 12. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 13. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:10:47.798691 [ 4529 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:57518). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e7596 8. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:314: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5ae808 9. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 10. ./build_docker/./src/Formats/NativeWriter.cpp:78: DB::NativeWriter::write(DB::Block const&) @ 0x000000003b0d630f 11. ./build_docker/./src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7dc0 12. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 13. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:10:48.570160 [ 10627 ] {3ad02189-55d7-420a-af37-a086ba788278} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(nan). (TOO_LARGE_STRING_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57684) (comment: 01054_random_printable_ascii_ubsan.sh) (query 1, line 1) (in query: SELECT randomPrintableASCII(nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:48.575064 [ 10627 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(nan). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:48.650899 [ 6019 ] {d9d77252-9f2a-489c-85a9-654ff797a89d} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(10000.1, 18). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 85, line 106) (in query: select toDecimal64(10000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:48.654045 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(10000.1, 18). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:49.359242 [ 4389 ] {ead1b4f3-7338-4520-9078-1cab09abf64a} executeQuery: Code: 386. DB::Exception: There is no supertype for types Tuple(Array(UInt8), UInt8), Tuple(Array(UInt8), UInt8, String, String, UInt8) because Tuples have different sizes: In scope SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table. (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57728) (comment: 01701_if_tuple_segfault.sql) (query 6, line 21) (in query: SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:387: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f551505 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000306c646a 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:10:49.363006 [ 4389 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(Array(UInt8), UInt8), Tuple(Array(UInt8), UInt8, String, String, UInt8) because Tuples have different sizes: In scope SELECT if(xxx = 'x', ([2], 3), ([3], 4, 'q', 'w', 7)) FROM agg_table. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:387: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f551505 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000306c646a 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:10:49.438245 [ 6070 ] {e3790f1e-a23b-4eae-822b-050cfb67e72a} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(inf). (TOO_LARGE_STRING_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57838) (comment: 01054_random_printable_ascii_ubsan.sh) (query 1, line 1) (in query: SELECT randomPrintableASCII(inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:49.445823 [ 6070 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(inf). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:49.775865 [ 10170 ] {d80c72ba-cd09-4763-9df3-0632dcc6ee04} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt8: while executing 'FUNCTION nullIn(-1_Int8 :: 2, __set_2981896477676004330_13741191019392472059 :: 1) -> nullIn(-1_Int8, __set_2981896477676004330_13741191019392472059) UInt8 : 3'. (CANNOT_CONVERT_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57470) (comment: 01600_select_in_different_types.sql) (query 24, line 35) (in query: SELECT -1 IN (SELECT 1) SETTINGS transform_null_in = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002c3cdf15 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator(), DB::DataTypeNumber>>(DB::DataTypeNumber const&) const @ 0x000000002c3bae81 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c3b7ff9 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b7b24 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000033776679 14. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000033777d5c 15. ./build_docker/./src/Interpreters/Set.cpp:470: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000033049a99 16. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x00000000116fa395 17. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000116f83d0 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 23. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 24. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 25. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 2025.11.13 09:10:49.781603 [ 10170 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt8: while executing 'FUNCTION nullIn(-1_Int8 :: 2, __set_2981896477676004330_13741191019392472059 :: 1) -> nullIn(-1_Int8, __set_2981896477676004330_13741191019392472059) UInt8 : 3'. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x000000002c3cdf15 5. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(DB::DataTypeNumber const&)::operator(), DB::DataTypeNumber>>(DB::DataTypeNumber const&) const @ 0x000000002c3bae81 6. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c3b7ff9 7. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b7b24 8. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 13. ./build_docker/./src/Interpreters/castColumn.cpp:39: DB::castColumn(DB::CastType, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000033776679 14. ./build_docker/./src/Interpreters/castColumn.cpp:49: DB::castColumnAccurate(DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DB::InternalCastFunctionCache*) @ 0x0000000033777d5c 15. ./build_docker/./src/Interpreters/Set.cpp:470: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000033049a99 16. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x00000000116fa395 17. DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000116f83d0 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 23. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 24. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 25. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 30. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:10:50.356427 [ 10610 ] {9dc99eb2-e428-4d79-951b-4787bc305c64} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-inf). (TOO_LARGE_STRING_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57924) (comment: 01054_random_printable_ascii_ubsan.sh) (query 1, line 1) (in query: SELECT randomPrintableASCII(-inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:50.361776 [ 10610 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-inf). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:51.366946 [ 5295 ] {d6168769-cff2-4636-90c4-1b765fd020a8} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(1e300). (TOO_LARGE_STRING_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57758) (comment: 01054_random_printable_ascii_ubsan.sh) (query 1, line 1) (in query: SELECT randomPrintableASCII(1e300);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:51.373168 [ 5295 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(1e300). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:51.601198 [ 6019 ] {7619b269-e67a-4183-97bd-c14cfd3c6631} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1e21, 18). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 86, line 107) (in query: select toDecimal128(1000000000000000000000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.604203 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1e21, 18). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.619226 [ 6019 ] {31cd6f61-b691-48c3-91c3-cb3d07d56c76} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-10000.1, 6). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 87, line 109) (in query: select toDecimal32(-10000.1, 6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.622915 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-10000.1, 6). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.638419 [ 6019 ] {06252ce1-4a13-4ab7-85d3-7910bd12d4c7} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-10000.1, 18). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 88, line 110) (in query: select toDecimal64(-10000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.642056 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-10000.1, 18). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.657415 [ 6019 ] {61d2d69f-934d-4054-b7d5-62b140825386} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1e21, 18). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 89, line 111) (in query: select toDecimal128(-1000000000000000000000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.660630 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1e21, 18). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.677393 [ 6019 ] {0aaea727-7dbd-45f4-9698-56f5850644e4} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(2147483647. + 1., 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 90, line 113) (in query: select toDecimal32(2147483647.0 + 1.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.680831 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(2147483647. + 1., 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.696744 [ 6019 ] {3d7672ff-e08e-41bc-8f7d-d4ba6c13e160} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(9223372036854776000., 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 91, line 114) (in query: select toDecimal64(9223372036854775807.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.699355 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(9223372036854776000., 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.714905 [ 6019 ] {b122175b-77af-4ae9-b3b0-19f4af00a2ba} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1.7014118346046923e38, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 92, line 115) (in query: select toDecimal128(170141183460469231731687303715884105729.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.718009 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1.7014118346046923e38, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.735128 [ 6019 ] {69b8bfeb-ce5b-4d86-af11-2c1c4ff1dc8a} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-2147483647. - 1., 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 93, line 117) (in query: select toDecimal32(-2147483647.0 - 1.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.738164 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-2147483647. - 1., 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.754794 [ 6019 ] {166f25a1-af1e-4435-9ee8-005a2534095d} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-9223372036854776000., 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 94, line 118) (in query: select toDecimal64(-9223372036854775807.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.759476 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-9223372036854776000., 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.775373 [ 6019 ] {6857acd2-e3e1-48a6-b503-0b2485151476} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1.7014118346046923e38, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48056) (comment: 00700_decimal_casts_2.sql) (query 95, line 119) (in query: select toDecimal128(-170141183460469231731687303715884105729.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:51.778745 [ 6019 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1.7014118346046923e38, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:10:52.316930 [ 10610 ] {d52a6240-54b4-4793-85c7-ee22c9992698} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-123.456). (TOO_LARGE_STRING_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57790) (comment: 01054_random_printable_ascii_ubsan.sh) (query 1, line 1) (in query: SELECT randomPrintableASCII(-123.456);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:52.323962 [ 10610 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-123.456). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:52.899485 [ 6029 ] {93ea0f04-1b22-463d-b369-dac4723b4155} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:57810). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e7596 8. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:314: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5ae808 9. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 10. ./build_docker/./src/Formats/NativeWriter.cpp:78: DB::NativeWriter::write(DB::Block const&) @ 0x000000003b0d630f 11. ./build_docker/./src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7dc0 12. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 13. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:53.067534 [ 6029 ] {93ea0f04-1b22-463d-b369-dac4723b4155} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:57810). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57810) (comment: 02003_memory_limit_in_client.sh) (query 1, line 1) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e7596 8. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:314: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5ae808 9. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 10. ./build_docker/./src/Formats/NativeWriter.cpp:78: DB::NativeWriter::write(DB::Block const&) @ 0x000000003b0d630f 11. ./build_docker/./src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7dc0 12. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 13. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:10:53.074859 [ 6029 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:57810). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e7596 8. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:314: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5ae808 9. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 10. ./build_docker/./src/Formats/NativeWriter.cpp:78: DB::NativeWriter::write(DB::Block const&) @ 0x000000003b0d630f 11. ./build_docker/./src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7dc0 12. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 13. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:10:53.334624 [ 4529 ] {20af2038-59e8-402f-b483-e195bb091ff1} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57870) (comment: 01054_random_printable_ascii_ubsan.sh) (query 1, line 1) (in query: SELECT randomPrintableASCII(-1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:53.340204 [ 4529 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a1876e0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:10:57.567811 [ 6078 ] {e77b1db8-fa4f-459e-8255-c5ec39626b1d} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:57900). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e7596 8. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:314: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5ae808 9. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 10. ./build_docker/./src/Formats/NativeWriter.cpp:78: DB::NativeWriter::write(DB::Block const&) @ 0x000000003b0d630f 11. ./build_docker/./src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7dc0 12. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 13. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:10:57.748203 [ 6078 ] {e77b1db8-fa4f-459e-8255-c5ec39626b1d} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:57900). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57900) (comment: 02003_memory_limit_in_client.sh) (query 1, line 1) (in query: SELECT arrayMap(x -> range(x), range(number)) FROM numbers(1000) -- { clientError MEMORY_LIMIT_EXCEEDED }), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e7596 8. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:314: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5ae808 9. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 10. ./build_docker/./src/Formats/NativeWriter.cpp:78: DB::NativeWriter::write(DB::Block const&) @ 0x000000003b0d630f 11. ./build_docker/./src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7dc0 12. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 13. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:10:57.752947 [ 6078 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:57900). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 7. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e7596 8. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:314: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5ae808 9. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 10. ./build_docker/./src/Formats/NativeWriter.cpp:78: DB::NativeWriter::write(DB::Block const&) @ 0x000000003b0d630f 11. ./build_docker/./src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7dc0 12. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 13. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:10:57.884950 [ 4759 ] {2c7d1ab5-72fd-4a09-b093-570ae04397d5} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57862) (comment: 00930_max_partitions_per_insert_block.sql) (query 9, line 12) (in query: INSERT INTO partitions SELECT * FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:119: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7dcd5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:10:57.890610 [ 4759 ] {} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:119: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7dcd5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:11:00.701678 [ 6023 ] {13d034e7-722b-407b-a1ca-090d3ee9c994} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59662) (comment: 03033_analyzer_resolve_from_parent_scope.sql) (in query: DROP DATABASE IF EXISTS test_1fmmlqlj SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:11:00.704141 [ 6023 ] {13d034e7-722b-407b-a1ca-090d3ee9c994} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:00.797453 [ 6067 ] {f8f714a6-1347-4384-873a-8de09405a46c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59664) (comment: 03033_analyzer_resolve_from_parent_scope.sql) (in query: DROP DATABASE IF EXISTS test_1fmmlqlj SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:11:00.799919 [ 6067 ] {f8f714a6-1347-4384-873a-8de09405a46c} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:02.428607 [ 4529 ] {7ae2bf3a-a050-4714-9a1f-e3b9edde8a5a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 30.65 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 30.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58052) (comment: 02228_merge_tree_insert_memory_usage.sql) (query 5, line 10) (in query: insert into data_02228 select number, 1, number from numbers_mt(10_000) settings max_memory_usage='30Mi', max_partitions_per_insert_block=1024, max_insert_delayed_streams_for_parallel_write=1000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 11. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 12. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 14. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 15. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 2025.11.13 09:11:02.518671 [ 4529 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 30.65 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 30.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 11. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 12. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 14. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 15. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:11:05.274091 [ 6019 ] {6d9fe5eb-06ca-4386-a862-97931ac91a73} executeQuery: Code: 80. DB::Exception: Failed to rewrite ', ...' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59394) (comment: 02364_setting_cross_to_inner_rewrite.sql) (query 13, line 17) (in query: SELECT count() = 1 FROM t1, t2 WHERE t1.x > t2.x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:355: DB::(anonymous namespace)::CrossToInnerJoinVisitor::checkNotRewritten(bool, std::shared_ptr const&) @ 0x000000003110484e 5. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:366: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x00000000310fc1d7 6. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:392: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000310f49ff 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:05.300278 [ 6019 ] {} TCPHandler: Code: 80. DB::Exception: Failed to rewrite ', ...' to INNER JOIN: no equi-join conditions found in WHERE clause. You may set setting `cross_to_inner_join_rewrite` to `1` to allow slow CROSS JOIN for this case. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:355: DB::(anonymous namespace)::CrossToInnerJoinVisitor::checkNotRewritten(bool, std::shared_ptr const&) @ 0x000000003110484e 5. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:366: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x00000000310fc1d7 6. ./build_docker/./src/Analyzer/Passes/CrossToInnerJoinPass.cpp:392: DB::CrossToInnerJoinPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000310f49ff 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:05.369353 [ 6067 ] {a0a14f18-d297-4029-95b4-af808be0a908} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different values of constants in column '1': actual: 1, expected: 3. (AMBIGUOUS_COLUMN_NAME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59384) (comment: 01101_literal_column_clash.sql) (query 5, line 10) (in query: with 3 as "1" select 1, "1";), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002eb22abf 4. ./build_docker/./src/Core/Block.cpp:41: void DB::onError>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002eb132d3 5. ./build_docker/./src/Core/Block.cpp:111: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002eaf75bd 6. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002eaf7dbc 7. ./build_docker/./src/Interpreters/ExpressionActions.cpp:464: DB::ExpressionActions::linearizeActions(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000031b5db84 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:65: DB::ExpressionActions::ExpressionActions(DB::ActionsDAG, DB::ExpressionActionsSettings const&, bool) @ 0x0000000031b5be19 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ExpressionActions* std::construct_at[abi:ne190107](DB::ExpressionActions*, DB::ActionsDAG&&, DB::ExpressionActionsSettings const&) @ 0x0000000030324407 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ExpressionStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c100c5d 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:05.372499 [ 6067 ] {} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different values of constants in column '1': actual: 1, expected: 3. (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002eb22abf 4. ./build_docker/./src/Core/Block.cpp:41: void DB::onError>&, String const&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String const&, String&&, String&&) @ 0x000000002eb132d3 5. ./build_docker/./src/Core/Block.cpp:111: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002eaf75bd 6. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002eaf7dbc 7. ./build_docker/./src/Interpreters/ExpressionActions.cpp:464: DB::ExpressionActions::linearizeActions(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000031b5db84 8. ./build_docker/./src/Interpreters/ExpressionActions.cpp:65: DB::ExpressionActions::ExpressionActions(DB::ActionsDAG, DB::ExpressionActionsSettings const&, bool) @ 0x0000000031b5be19 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ExpressionActions* std::construct_at[abi:ne190107](DB::ExpressionActions*, DB::ActionsDAG&&, DB::ExpressionActionsSettings const&) @ 0x0000000030324407 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ExpressionStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c100c5d 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:06.004649 [ 6067 ] {130bd9b9-0236-4886-9fed-a5f838c6e6f9} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(UInt8) Nullable(size = 0, UInt8(size = 0), UInt8(size = 0)). (AMBIGUOUS_COLUMN_NAME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59384) (comment: 01101_literal_column_clash.sql) (query 6, line 12) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/9953 select 1, * from (select 2 x) a left join (select 1, 3 y) b on y = x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002eaf5e62 4. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002eaf7dbc 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:906: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f9c64 6. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 7. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 9. ./build_docker/./src/Planner/Planner.cpp:1828: DB::Planner::buildPlanForQueryNode() @ 0x0000000032c026ab 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:11:06.009361 [ 6067 ] {} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(UInt8) Nullable(size = 0, UInt8(size = 0), UInt8(size = 0)). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002eaf5e62 4. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002eaf7dbc 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:906: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f9c64 6. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 7. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 9. ./build_docker/./src/Planner/Planner.cpp:1828: DB::Planner::buildPlanForQueryNode() @ 0x0000000032c026ab 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:11:07.268392 [ 10609 ] {de4c0787-d8d3-4436-902c-428b04ea50b4} executeQuery: Code: 33. DB::Exception: Error while parsing Nullable: got an unquoted string n instead of a number: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_rhqjuko0.data): While executing CustomSeparatedRowInputFormat: While executing File. (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59462) (comment: 02130_parse_quoted_null.sh) (query 1, line 1) (in query: select * from file('test_rhqjuko0.data', 'CustomSeparated', 'x Nullable(Float64), y Nullable(UInt64)') settings input_format_parallel_parsing=0, format_custom_escaping_rule='Quoted'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:530: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&)::'lambda0'(DB::IColumn&, DB::ReadBuffer&)::operator()(DB::IColumn&, DB::ReadBuffer&) const @ 0x000000002f6d8531 5. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:211: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000002f6ce150 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:544: DB::SerializationNullable::deserializeTextQuoted(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6c9bde 7. ./build_docker/./src/Formats/EscapingRuleUtils.cpp:117: DB::deserializeFieldByEscapingRule(std::shared_ptr const&, std::shared_ptr const&, DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings::EscapingRule, DB::FormatSettings const&) @ 0x000000003af8be7a 8. ./build_docker/./src/Processors/Formats/Impl/CustomSeparatedRowInputFormat.cpp:295: DB::CustomSeparatedFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003b590335 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e78f 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x000000003851b412 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:11:07.276043 [ 10609 ] {} TCPHandler: Code: 33. DB::Exception: Error while parsing Nullable: got an unquoted string n instead of a number: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_rhqjuko0.data): While executing CustomSeparatedRowInputFormat: While executing File. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:530: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&)::'lambda0'(DB::IColumn&, DB::ReadBuffer&)::operator()(DB::IColumn&, DB::ReadBuffer&) const @ 0x000000002f6d8531 5. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:211: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000002f6ce150 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:544: DB::SerializationNullable::deserializeTextQuoted(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6c9bde 7. ./build_docker/./src/Formats/EscapingRuleUtils.cpp:117: DB::deserializeFieldByEscapingRule(std::shared_ptr const&, std::shared_ptr const&, DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings::EscapingRule, DB::FormatSettings const&) @ 0x000000003af8be7a 8. ./build_docker/./src/Processors/Formats/Impl/CustomSeparatedRowInputFormat.cpp:295: DB::CustomSeparatedFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003b590335 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e78f 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x000000003851b412 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:11:09.669541 [ 10181 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:11:09.670043 [ 10181 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:11:10.074499 [ 4529 ] {0513cc2c-0d81-4ce4-b61d-75c01743392f} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 30.65 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 30.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58052) (comment: 02228_merge_tree_insert_memory_usage.sql) (query 10, line 16) (in query: insert into data_rep_02228 select number, 1, number from numbers_mt(10_000) settings max_memory_usage='30Mi', max_partitions_per_insert_block=1024, max_insert_delayed_streams_for_parallel_write=1000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 11. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 12. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 14. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 15. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:373: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a3c209c 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 2025.11.13 09:11:10.085784 [ 4529 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 30.65 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 30.00 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 11. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 12. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 14. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 15. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:373: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a3c209c 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:11:10.893881 [ 10181 ] {960b8e68-8430-41d4-acd3-f6bb98cfa24c} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 4, line 4) (in query: SELECT BLAKE3(NULL, NULL, NULL);) 2025.11.13 09:11:10.898202 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:10.937720 [ 10181 ] {997139d9-c1b2-468d-9e17-b7fcfe910fc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 5, line 6) (in query: SELECT CHARACTER_LENGTH(NULL, NULL, NULL);) 2025.11.13 09:11:10.954684 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:10.969025 [ 10181 ] {e94ccfd7-2246-49d7-b5ba-9c79e858e5e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 6, line 7) (in query: SELECT CHAR_LENGTH(NULL, NULL, NULL);) 2025.11.13 09:11:11.031732 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:11.182102 [ 10181 ] {c6201397-2f70-443a-afcb-dc8ff259b2d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 9, line 10) (in query: SELECT CRC32(NULL, NULL, NULL);) 2025.11.13 09:11:11.186107 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:11.226274 [ 10181 ] {b65c5867-c503-48a4-8283-bcccbfae8c7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 10, line 11) (in query: SELECT CRC32IEEE(NULL, NULL, NULL);) 2025.11.13 09:11:11.229837 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:11.268682 [ 10181 ] {31c06165-2c83-4b26-9102-6785f6d80599} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 11, line 12) (in query: SELECT CRC64(NULL, NULL, NULL);) 2025.11.13 09:11:11.272782 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:11.301401 [ 10181 ] {475f301c-069a-401d-a02d-638556e414b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 12, line 13) (in query: SELECT DATABASE(NULL, NULL, NULL);) 2025.11.13 09:11:11.305264 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:11.823931 [ 4389 ] {aa60027f-cc76-4be2-af18-96e3a5eed481} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=915, jobs=835). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58204) (comment: 00233_position_function_family.sql) (query 155, line 183) (in query: select 0 = positionCaseInsensitive(materialize(''), 'аБв');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:11:11.846336 [ 4389 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=915, jobs=835). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:11:11.856994 [ 10181 ] {a53029dc-e62f-4ea4-97c1-e83dd272bd8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 21, line 22) (in query: SELECT FORMAT_BYTES(NULL, NULL, NULL);) 2025.11.13 09:11:11.865619 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:11.927642 [ 10181 ] {a9069a6c-5c86-4e55-a33b-4a11cf3ac5a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 22, line 23) (in query: SELECT FQDN(NULL, NULL, NULL);) 2025.11.13 09:11:11.941963 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:11.964032 [ 10181 ] {6e9b1f0e-ca1c-410d-a413-045539123717} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 23, line 24) (in query: SELECT FROM_BASE64(NULL, NULL, NULL);) 2025.11.13 09:11:11.998355 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.018845 [ 10181 ] {186b667b-7a8d-4489-bb2d-55393b37bd11} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 24, line 25) (in query: SELECT FROM_DAYS(NULL, NULL, NULL);) 2025.11.13 09:11:12.036297 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.208942 [ 10181 ] {54a4b9c1-78d2-492d-aae8-43fd88a397d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 27, line 28) (in query: SELECT INET6_ATON(NULL, NULL, NULL);) 2025.11.13 09:11:12.227906 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.252748 [ 10181 ] {ac0f8469-eb7b-47f9-83bf-682caa066a81} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 28, line 29) (in query: SELECT INET6_NTOA(NULL, NULL, NULL);) 2025.11.13 09:11:12.268254 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.316921 [ 10181 ] {00d53fe2-dcf9-4eff-960a-9ca0ee7de94c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 29, line 30) (in query: SELECT INET_ATON(NULL, NULL, NULL);) 2025.11.13 09:11:12.333113 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.354051 [ 10181 ] {4f62ab1c-b8df-40d8-80a7-62ae953755fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 30, line 31) (in query: SELECT INET_NTOA(NULL, NULL, NULL);) 2025.11.13 09:11:12.359796 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.408225 [ 10181 ] {6d466bb5-ca03-4825-b76c-9d3a5686c524} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 31, line 32) (in query: SELECT IPv4CIDRToRange(NULL, NULL, NULL);) 2025.11.13 09:11:12.417634 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.437289 [ 10181 ] {82a748bf-b3f0-4404-8c9b-e44ded9118b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 32, line 33) (in query: SELECT IPv4NumToString(NULL, NULL, NULL);) 2025.11.13 09:11:12.441051 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.465751 [ 10181 ] {b8ec1217-93d9-4338-8f2e-c869d40ed7ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 33, line 34) (in query: SELECT IPv4NumToStringClassC(NULL, NULL, NULL);) 2025.11.13 09:11:12.469598 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.505400 [ 10181 ] {2a7dc48d-c402-402b-8596-74011a7db65b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 34, line 35) (in query: SELECT IPv4StringToNum(NULL, NULL, NULL);) 2025.11.13 09:11:12.510729 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.539738 [ 10181 ] {aaf3c762-de33-4985-9a89-06feb0ec1a96} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 35, line 36) (in query: SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL);) 2025.11.13 09:11:12.635044 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.667360 [ 10181 ] {89d674d9-ad84-4e8e-b967-00c245c049fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 36, line 37) (in query: SELECT IPv4StringToNumOrNull(NULL, NULL, NULL);) 2025.11.13 09:11:12.671301 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.695632 [ 10181 ] {bdbc6122-661c-4a84-a778-f36f6a6c83f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 37, line 38) (in query: SELECT IPv4ToIPv6(NULL, NULL, NULL);) 2025.11.13 09:11:12.699396 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.728488 [ 10181 ] {cf86ba4d-2585-4c10-b9c0-529910e9e61a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 38, line 39) (in query: SELECT IPv6CIDRToRange(NULL, NULL, NULL);) 2025.11.13 09:11:12.732404 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.761722 [ 10181 ] {1d32b744-1ed2-4000-b387-4038192b3c97} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 39, line 40) (in query: SELECT IPv6NumToString(NULL, NULL, NULL);) 2025.11.13 09:11:12.773628 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.793935 [ 10181 ] {869adf6f-a2ab-4d8e-a7ea-d99855a71cf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 40, line 41) (in query: SELECT IPv6StringToNum(NULL, NULL, NULL);) 2025.11.13 09:11:12.806480 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.880004 [ 10181 ] {c37d2231-d070-4ab4-abf1-352bda75d6b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 41, line 42) (in query: SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL);) 2025.11.13 09:11:12.893485 [ 6092 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:11:12.896530 [ 6092 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:11:12.897846 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.913455 [ 10181 ] {9541c993-c0fe-49c8-84b3-82d2225a93be} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 42, line 43) (in query: SELECT IPv6StringToNumOrNull(NULL, NULL, NULL);) 2025.11.13 09:11:12.930299 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:12.944536 [ 10181 ] {37daa2da-fc22-46fd-83bd-47b2936b06a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 43, line 44) (in query: SELECT JSONAllPaths(NULL, NULL, NULL);) 2025.11.13 09:11:12.945167 [ 6028 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:12.945506 [ 6028 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:12.948600 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:13.045720 [ 10181 ] {71126bee-218b-41a5-97c9-8f3bb816b9a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 44, line 45) (in query: SELECT JSONAllPathsWithTypes(NULL, NULL, NULL);) 2025.11.13 09:11:13.049845 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:13.083068 [ 10181 ] {5a17a801-5af9-4993-b603-67c8e9881cbc} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 45, line 46) (in query: SELECT JSONArrayLength(NULL, NULL, NULL);) 2025.11.13 09:11:13.093657 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:13.192537 [ 10181 ] {999d4616-1605-4001-8a7e-9583e7d5f1de} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 46, line 47) (in query: SELECT JSONDynamicPaths(NULL, NULL, NULL);) 2025.11.13 09:11:13.196904 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:13.224180 [ 10181 ] {e735b1de-5495-4283-80cd-3a92d009e494} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 47, line 48) (in query: SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL);) 2025.11.13 09:11:13.237480 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:13.266475 [ 10181 ] {e4fa5926-3e45-4b13-955a-eb9033f048b4} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 48, line 49) (in query: SELECT JSONExtract(NULL, NULL, NULL);) 2025.11.13 09:11:13.358560 [ 10181 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.11.13 09:11:13.376643 [ 6023 ] {457316b6-ec3e-4f69-82e8-c687c20f4a9f} executeQuery: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 . (AUTHENTICATION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41638) (comment: 01119_session_log.sh) (query 2, line 3) (in query: SELECT * FROM remote('127.0.0.2', system, one, 'default', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x000000003aa7f26f 5. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa76083 6. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 7. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:11:13.380845 [ 6023 ] {} TCPHandler: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x000000003aa7f26f 5. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa76083 6. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 7. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:11:13.423637 [ 6092 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: nonexistsnt_user_1119: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:13.423947 [ 6092 ] {} ServerErrorHandler: Code: 516. DB::Exception: nonexistsnt_user_1119: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:13.428929 [ 6023 ] {10ac9a58-9896-4432-adb8-f24e563f6cd3} executeQuery: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: nonexistsnt_user_1119: Authentication failed: password is incorrect, or there is no user with such name.. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 . (AUTHENTICATION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41638) (comment: 01119_session_log.sh) (query 3, line 4) (in query: SELECT * FROM remote('127.0.0.2', system, one, 'nonexistsnt_user_1119', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x000000003aa7f26f 5. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa76083 6. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 7. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:11:13.432340 [ 6023 ] {} TCPHandler: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: nonexistsnt_user_1119: Authentication failed: password is incorrect, or there is no user with such name.. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x000000003aa7f26f 5. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa76083 6. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 7. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:11:13.545253 [ 10609 ] {e3fec6a6-d6f9-4277-a142-2ee7df3a6f0a} executeQuery: Code: 53. DB::Exception: Cannot convert string '2020-03-04 10:20:45' to type Date. (TYPE_MISMATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 8, line 21) (in query: SELECT count() FROM datetime_date_table WHERE col_date > '2020-03-04 10:20:45';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337824ec 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f216dd9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cd514 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 18. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 19. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:11:13.548129 [ 10609 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '2020-03-04 10:20:45' to type Date. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337824ec 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f216dd9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cd514 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 18. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 19. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:11:13.696677 [ 10181 ] {cc19071f-425a-4904-9b12-31b17baa995c} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 54, line 55) (in query: SELECT JSONExtractKeysAndValues(NULL, NULL, NULL);) 2025.11.13 09:11:13.702010 [ 10181 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.11.13 09:11:13.824797 [ 10609 ] {c71ee5e4-68d4-4748-8e98-36ca5a85f000} executeQuery: Code: 53. DB::Exception: Cannot convert string '2020-03-04 10:20:45.100' to type Date. (TYPE_MISMATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 10, line 23) (in query: SELECT count() FROM datetime_date_table WHERE col_date > '2020-03-04 10:20:45.100';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337824ec 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f216dd9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cd514 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 18. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 19. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:11:13.828148 [ 10609 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '2020-03-04 10:20:45.100' to type Date. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337824ec 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f216dd9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cd514 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 18. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 19. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:11:14.234863 [ 10181 ] {0eb25e2b-f446-4efc-9fa8-f2c025931c26} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 63, line 64) (in query: SELECT JSONSharedDataPaths(NULL, NULL, NULL);) 2025.11.13 09:11:14.239670 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:14.279545 [ 10181 ] {b83f2303-a49f-45cb-8667-0e01491d4a96} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 64, line 65) (in query: SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL);) 2025.11.13 09:11:14.283730 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:14.437075 [ 10181 ] {cee6711e-279d-4bfc-9c19-0651376869b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 66, line 67) (in query: SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL);) 2025.11.13 09:11:14.442383 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:14.475313 [ 4390 ] {11a572e0-34ca-4a6b-9b59-a94e3d17adf6} executeQuery: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41672) (comment: 02304_grouping_sets_with_rollup_cube.sql) (query 1, line 1) (in query: SELECT number FROM numbers(10) GROUP BY GROUPING SETS ( number, number % 2 ) WITH ROLLUP;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5488: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030401dd9 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:14.479433 [ 4390 ] {} TCPHandler: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5488: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030401dd9 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:14.498502 [ 4390 ] {488c2dac-23e7-4c0e-ae23-1114bb762085} executeQuery: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41672) (comment: 02304_grouping_sets_with_rollup_cube.sql) (query 2, line 13) (in query: SELECT number FROM numbers(10) GROUP BY GROUPING SETS ( number, number % 2 ) WITH CUBE;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5488: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030401dd9 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:14.502580 [ 4390 ] {} TCPHandler: Code: 48. DB::Exception: GROUPING SETS are not supported together with ROLLUP and CUBE. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5488: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030401dd9 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:14.538937 [ 6028 ] {6b21071e-56f1-4186-b896-a8eacdc397bd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=915, jobs=836). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41720) (comment: 00800_low_cardinality_join.sql) (query 4, line 5) (in query: select * from (select toLowCardinality(dummy) as val from system.one) any left join (select dummy as val from system.one) using val order by all;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:11:14.545713 [ 6028 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=915, jobs=836). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:11:14.649228 [ 10181 ] {59d1c132-9885-48b1-9c48-c17abe81a709} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 70, line 71) (in query: SELECT L1Distance(NULL, NULL, NULL);) 2025.11.13 09:11:14.654687 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:14.654727 [ 10609 ] {59ab42f8-0e59-4a7a-bbdf-d448af78e7df} executeQuery: Code: 53. DB::Exception: Cannot convert string '2020-03-04 10:20:45.100' to type DateTime. (TYPE_MISMATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 17, line 31) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime > '2020-03-04 10:20:45.100';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337824ec 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f216dd9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cd514 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 18. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 19. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:11:14.658741 [ 10609 ] {} TCPHandler: Code: 53. DB::Exception: Cannot convert string '2020-03-04 10:20:45.100' to type DateTime. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:583: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337824ec 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f216dd9 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cd514 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 18. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 19. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 20. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:11:14.681825 [ 10181 ] {a7093702-51b7-4c2e-a81c-03fd1c2c54c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 71, line 72) (in query: SELECT L1Norm(NULL, NULL, NULL);) 2025.11.13 09:11:14.687142 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:14.783157 [ 10181 ] {b20449e8-a2c5-4a73-b07f-49a25883d043} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 72, line 73) (in query: SELECT L1Normalize(NULL, NULL, NULL);) 2025.11.13 09:11:14.789336 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:14.819067 [ 10181 ] {10cf83b3-06e1-4b51-9ae6-24693a1d3c26} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 73, line 74) (in query: SELECT L2Distance(NULL, NULL, NULL);) 2025.11.13 09:11:14.823430 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:14.900200 [ 10181 ] {b25bc4bf-4afc-4749-9e73-105e1f0d1c3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 74, line 75) (in query: SELECT L2Norm(NULL, NULL, NULL);) 2025.11.13 09:11:14.904675 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:14.946826 [ 10181 ] {2f876435-d18c-4d0e-9d48-cc3d4d0cee94} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 75, line 76) (in query: SELECT L2Normalize(NULL, NULL, NULL);) 2025.11.13 09:11:14.951151 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:14.980928 [ 10181 ] {7ed79f36-85b5-49d7-a34f-b73d20221438} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 76, line 77) (in query: SELECT L2SquaredDistance(NULL, NULL, NULL);) 2025.11.13 09:11:14.985419 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.020314 [ 10181 ] {73e454c8-c06f-47c8-846e-e22e50efd94d} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 77, line 78) (in query: SELECT L2SquaredNorm(NULL, NULL, NULL);) 2025.11.13 09:11:15.027242 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.262480 [ 10181 ] {6fb19444-95d6-41b9-8617-696584b169dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 79, line 80) (in query: SELECT LinfDistance(NULL, NULL, NULL);) 2025.11.13 09:11:15.277376 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.297561 [ 10181 ] {fe845d26-3874-4494-b652-934568070218} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 80, line 81) (in query: SELECT LinfNorm(NULL, NULL, NULL);) 2025.11.13 09:11:15.303286 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.328394 [ 10181 ] {4061771b-63fa-4a29-bb94-9fa2c6335ccb} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 81, line 82) (in query: SELECT LinfNormalize(NULL, NULL, NULL);) 2025.11.13 09:11:15.333638 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.402474 [ 10181 ] {94078b9f-3be8-4f20-be5d-d660ffa0bf69} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 83, line 84) (in query: SELECT LpNorm(NULL, NULL, NULL);) 2025.11.13 09:11:15.408409 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.436966 [ 10181 ] {fd2043ed-4545-4811-86c7-869d8f3d13f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 84, line 85) (in query: SELECT LpNormalize(NULL, NULL, NULL);) 2025.11.13 09:11:15.440763 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.469534 [ 10181 ] {75c712f6-947f-47af-9e57-0726a893a627} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 85, line 86) (in query: SELECT MACNumToString(NULL, NULL, NULL);) 2025.11.13 09:11:15.474238 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.501099 [ 10181 ] {12210f9b-7548-4831-8959-935817827d04} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 86, line 87) (in query: SELECT MACStringToNum(NULL, NULL, NULL);) 2025.11.13 09:11:15.513770 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.575294 [ 10181 ] {fda496a5-cfbd-4ffd-a23a-12d2566ed8de} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 87, line 88) (in query: SELECT MACStringToOUI(NULL, NULL, NULL);) 2025.11.13 09:11:15.585763 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.608180 [ 10181 ] {025e2ea2-6d05-4ed7-998c-c156c57786d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 88, line 89) (in query: SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL);) 2025.11.13 09:11:15.612258 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.675497 [ 10181 ] {d127108f-81c3-4b51-b739-1fa7f5616a8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 89, line 90) (in query: SELECT MD4(NULL, NULL, NULL);) 2025.11.13 09:11:15.679634 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.721615 [ 10181 ] {017deaba-f4a6-48cc-a2be-153283a1991b} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 90, line 91) (in query: SELECT MD5(NULL, NULL, NULL);) 2025.11.13 09:11:15.732508 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:15.985593 [ 8245 ] {f7d649db-d867-431e-864f-c64735a0eff4} ExternalDictionariesLoader: Could not update external dictionary '4638ba79-9d5d-41fa-8223-c926066b36b7', leaving the previous version: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:211: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x00000000272e5730 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea37b 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:15.998447 [ 6082 ] {f7d649db-d867-431e-864f-c64735a0eff4} executeQuery: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41706) (comment: 02504_regexp_dictionary_table_source.sql) (query 22, line 59) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:211: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x00000000272e5730 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea37b 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:11:16.001927 [ 6082 ] {} TCPHandler: Code: 489. DB::Exception: There are duplicate id 6. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:211: DB::RegExpTreeDictionary::initRegexNodes(DB::Block&) @ 0x00000000272e5730 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:330: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea37b 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:11:16.235683 [ 10181 ] {ba2464ea-3724-442e-befb-c99075b6c703} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 94, line 95) (in query: SELECT OCTET_LENGTH(NULL, NULL, NULL);) 2025.11.13 09:11:16.336248 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:16.660397 [ 10181 ] {50f32224-3f39-4728-85e7-b030e7be9ced} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 97, line 98) (in query: SELECT REGEXP_MATCHES(NULL, NULL, NULL);) 2025.11.13 09:11:16.666395 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:16.812195 [ 10181 ] {8bbe2b8f-d386-4c6c-9dc7-b151f46de5d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 99, line 100) (in query: SELECT RIPEMD160(NULL, NULL, NULL);) 2025.11.13 09:11:16.819953 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:16.854652 [ 10181 ] {4cbed47b-1a21-428f-8503-4adf8d18520a} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 100, line 101) (in query: SELECT SCHEMA(NULL, NULL, NULL);) 2025.11.13 09:11:16.863195 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:16.962134 [ 10609 ] {eced6704-8249-40a0-ad62-4d2dd9e20375} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 21, line 36) (in query: SELECT count() FROM datetime_date_table WHERE col_date_string > '2020-03-04'::Date;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:16.967992 [ 10609 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:17.034457 [ 10181 ] {6be176d6-7b9e-4669-b668-ac0162aba0dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 102, line 103) (in query: SELECT SHA1(NULL, NULL, NULL);) 2025.11.13 09:11:17.042324 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:17.080132 [ 10181 ] {0cce4631-f1f5-44d8-a531-44b58e8b21fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 103, line 104) (in query: SELECT SHA224(NULL, NULL, NULL);) 2025.11.13 09:11:17.084606 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:17.108411 [ 10609 ] {9eb103b3-b1aa-486c-b5b2-a7aa8b196f58} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 23, line 38) (in query: SELECT count() FROM datetime_date_table WHERE col_date_string > '2020-03-04 10:20:45'::DateTime;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:17.115737 [ 10609 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:17.117191 [ 10181 ] {a18d109c-3dda-4a07-a3cf-20628c084a2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 104, line 105) (in query: SELECT SHA256(NULL, NULL, NULL);) 2025.11.13 09:11:17.121449 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:17.168339 [ 10181 ] {5a8639f8-ec42-414d-9e02-eb080b1f1f90} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 105, line 106) (in query: SELECT SHA384(NULL, NULL, NULL);) 2025.11.13 09:11:17.172931 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:17.362066 [ 10181 ] {4350120c-ae41-4b6e-8e4f-0f25fdb386c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 106, line 107) (in query: SELECT SHA512(NULL, NULL, NULL);) 2025.11.13 09:11:17.366237 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:17.395470 [ 10181 ] {7bb941fb-f044-4e2a-9975-9d00a9bb0797} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 107, line 108) (in query: SELECT SHA512_256(NULL, NULL, NULL);) 2025.11.13 09:11:17.402707 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:18.077272 [ 10627 ] {bc616ce7-8f17-47e8-b0c4-42d11c599968} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41778). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41778) (comment: 02922_deduplication_with_zero_copy.sh) (query 1, line 1) (in query: insert into r2 values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x000000003aea4d5d 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:11:18.080900 [ 10627 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41778). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x000000003aea4d5d 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:11:18.475897 [ 10181 ] {c643f974-6685-471b-b436-049f3ea187b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 114, line 115) (in query: SELECT TO_BASE64(NULL, NULL, NULL);) 2025.11.13 09:11:18.483700 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:18.819953 [ 9871 ] {4cb01f57-aee1-4c61-b78c-b9a1dbf133d9} ExternalDictionariesLoader: Could not update external dictionary '4638ba79-9d5d-41fa-8223-c926066b36b7', leaving the previous version: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e94fa 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:18.843225 [ 10181 ] {e0bbfed1-b587-4bb2-bd8e-15328b3cc974} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 119, line 120) (in query: SELECT URLHierarchy(NULL, NULL, NULL);) 2025.11.13 09:11:18.848931 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:18.889172 [ 10181 ] {59c7ac89-df8a-458f-8887-b5cdee18dd45} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 120, line 121) (in query: SELECT URLPathHierarchy(NULL, NULL, NULL);) 2025.11.13 09:11:18.899784 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:18.933373 [ 6082 ] {4cb01f57-aee1-4c61-b78c-b9a1dbf133d9} executeQuery: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41706) (comment: 02504_regexp_dictionary_table_source.sql) (query 25, line 64) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e94fa 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:11:18.945149 [ 6082 ] {} TCPHandler: Code: 489. DB::Exception: Unknown parent id 2 in regexp tree dictionary. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:295: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e94fa 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:11:18.971741 [ 10181 ] {d46f100e-cdcb-40d2-ba74-03cfc2e02ce3} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 121, line 122) (in query: SELECT UTCTimestamp(NULL, NULL, NULL);) 2025.11.13 09:11:18.989823 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:19.027658 [ 10181 ] {dba28e43-5c81-45b5-b990-2357ebba568d} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 122, line 123) (in query: SELECT UTC_timestamp(NULL, NULL, NULL);) 2025.11.13 09:11:19.039572 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:19.382710 [ 10609 ] {165e196c-344a-4d65-9f8c-a60f47f3a631} executeQuery: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 25, line 40) (in query: SELECT count() FROM datetime_date_table WHERE col_date_string > '2020-03-04 10:20:45.100'::DateTime64(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1d0e52 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 15. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 16. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:19.424304 [ 10609 ] {} TCPHandler: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1d0e52 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 15. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 16. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:19.543663 [ 16213 ] {76f5019d-cc0b-4dfe-92fc-195e7172b074} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46960) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT TSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b71447d 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b22527f 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:19.559072 [ 16213 ] {76f5019d-cc0b-4dfe-92fc-195e7172b074} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b71447d 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b22527f 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:19.805311 [ 10609 ] {8d5d27ef-ca22-4fb4-a302-c98685ae5880} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 28, line 44) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_string > '2020-03-04'::Date;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:19.818669 [ 10609 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:20.066533 [ 10609 ] {9d93e60c-b259-4bdb-918b-aaad68bef977} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 30, line 46) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_string > '2020-03-04 10:20:45'::DateTime;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:20.075224 [ 10609 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:20.279836 [ 10181 ] {8fe8ba06-56c0-4494-9a7c-ab696e3fc746} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 134, line 135) (in query: SELECT _CAST(NULL, NULL, NULL);) 2025.11.13 09:11:20.284852 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:20.286735 [ 16200 ] {dcd38672-c540-45e6-9200-a599759f7131} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47246) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT TSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:125: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b715404 9. ./src/Processors/Formats/IOutputFormat.h:103: DB::IOutputFormat::work() @ 0x000000003b224ff5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:20.290136 [ 16200 ] {dcd38672-c540-45e6-9200-a599759f7131} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:125: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b715404 9. ./src/Processors/Formats/IOutputFormat.h:103: DB::IOutputFormat::work() @ 0x000000003b224ff5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:20.293436 [ 6070 ] {9067d02f-71c7-4b42-ba00-21ab3055cc0d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=917, jobs=903). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47514) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT TSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003afc6559 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:105: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003afc5539 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ParallelFormattingOutputFormat* std::construct_at[abi:ne190107](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003afc3e7d 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003afa73fa 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1847: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000033842658 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:11:20.296588 [ 6070 ] {9067d02f-71c7-4b42-ba00-21ab3055cc0d} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=917, jobs=903). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003afc6559 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:105: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003afc5539 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ParallelFormattingOutputFormat* std::construct_at[abi:ne190107](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003afc3e7d 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003afa73fa 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1847: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000033842658 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:20.327039 [ 10181 ] {0ebf78d4-dafe-4a40-9244-559861d900ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 135, line 136) (in query: SELECT __actionName(NULL, NULL, NULL);) 2025.11.13 09:11:20.341058 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:20.395919 [ 10181 ] {6094c9cd-43a1-40f7-bc91-18d9e3c40e9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 136, line 137) (in query: SELECT __bitBoolMaskAnd(NULL, NULL, NULL);) 2025.11.13 09:11:20.405116 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:20.456645 [ 10181 ] {1fb6b73a-39d5-4aaf-9cb0-de216fb50c0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 137, line 138) (in query: SELECT __bitBoolMaskOr(NULL, NULL, NULL);) 2025.11.13 09:11:20.467865 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:20.513349 [ 10181 ] {41d86ac6-f231-4278-86da-60faae81cd33} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 138, line 139) (in query: SELECT __bitSwapLastTwo(NULL, NULL, NULL);) 2025.11.13 09:11:20.519753 [ 10609 ] {887e6100-7667-409c-9442-dd730ebc6d0b} executeQuery: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 32, line 48) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_string > '2020-03-04 10:20:45.100'::DateTime64(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1d0e52 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 15. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 16. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:20.521025 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:20.524576 [ 10609 ] {} TCPHandler: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1d0e52 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 15. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 16. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:20.548136 [ 10181 ] {4e6ccff2-5b28-44cf-8e51-699d89562ffa} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 139, line 140) (in query: SELECT __bitWrapperFunc(NULL, NULL, NULL);) 2025.11.13 09:11:20.552926 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:20.594679 [ 10181 ] {4dd344af-aece-4153-972d-8a883dbb7636} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 140, line 141) (in query: SELECT __getScalar(NULL, NULL, NULL);) 2025.11.13 09:11:20.599074 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:20.650886 [ 10181 ] {c61a9453-ea53-4018-a1ae-6ae8b15f4360} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 141, line 142) (in query: SELECT __scalarSubqueryResult(NULL, NULL, NULL);) 2025.11.13 09:11:20.657583 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:20.699974 [ 10181 ] {f81324e3-53be-4aa4-ad99-58ca618e371e} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 142, line 143) (in query: SELECT abs(NULL, NULL, NULL);) 2025.11.13 09:11:20.807070 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:20.830043 [ 10181 ] {0696afdd-8474-4ef0-b03d-a9bd2432ba7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 143, line 144) (in query: SELECT accurateCast(NULL, NULL, NULL);) 2025.11.13 09:11:20.839367 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:20.963450 [ 10181 ] {a494d336-40c6-45bf-9b33-264f8e7d4c41} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 144, line 145) (in query: SELECT accurateCastOrDefault(NULL, NULL, NULL);) 2025.11.13 09:11:20.970837 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:21.021602 [ 10181 ] {018ab136-15d1-466f-89fa-4e06d40f8749} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 145, line 146) (in query: SELECT accurateCastOrNull(NULL, NULL, NULL);) 2025.11.13 09:11:21.030025 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:21.064784 [ 10181 ] {01a00047-e26e-4057-9d82-8dd522dcf634} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 146, line 147) (in query: SELECT acos(NULL, NULL, NULL);) 2025.11.13 09:11:21.069396 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:21.118955 [ 10181 ] {68cc8410-cb8c-4742-85a1-77450b1ed8c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 147, line 148) (in query: SELECT acosh(NULL, NULL, NULL);) 2025.11.13 09:11:21.129141 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:21.209633 [ 10181 ] {f329d66d-da5e-434a-95ac-d80302137209} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 148, line 149) (in query: SELECT addDate(NULL, NULL, NULL);) 2025.11.13 09:11:21.218629 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:21.710267 [ 10181 ] {d55df332-1575-40a9-96cc-052e7e829cab} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 151, line 152) (in query: SELECT addInterval(NULL, NULL, NULL);) 2025.11.13 09:11:21.716734 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:22.610790 [ 10181 ] {9e7fc9b4-a5e2-4ff0-8c9a-acac9fa3aa87} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 159, line 160) (in query: SELECT addTupleOfIntervals(NULL, NULL, NULL);) 2025.11.13 09:11:22.615693 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:22.866610 [ 10181 ] {23e3a232-b932-462f-b169-f7b270388b3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 162, line 163) (in query: SELECT addressToLine(NULL, NULL, NULL);) 2025.11.13 09:11:22.872873 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:22.874169 [ 10609 ] {7673a7a8-e4c5-40b0-911d-8f5e32f03d27} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 35, line 52) (in query: SELECT count() FROM datetime_date_table WHERE col_date_lc > '2020-03-04'::Date;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:22.885467 [ 10609 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:22.886567 [ 10211 ] {5b6e4f86-7955-48b7-81f5-a26ac094756e} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.01 MiB (attempt to allocate chunk of 1.01 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47796) (comment: 01513_defaults_on_defaults_no_column.sql) (query 10, line 22) (in query: SELECT 1 AS `1` FROM `test_11`.`defaults_on_defaults` AS `__table1` WHERE `__table1`.`Arr.C4.size0` = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:22.899510 [ 10211 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.01 MiB (attempt to allocate chunk of 1.01 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:22.910947 [ 10181 ] {0c09dc82-861f-468c-a3bc-f16827ce0ccc} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 163, line 164) (in query: SELECT addressToLineWithInlines(NULL, NULL, NULL);) 2025.11.13 09:11:22.915386 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:22.962319 [ 10181 ] {f9b538e5-4d87-405c-a0f6-444932892a8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 164, line 165) (in query: SELECT addressToSymbol(NULL, NULL, NULL);) 2025.11.13 09:11:22.974226 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:23.035928 [ 6029 ] {02cc6851-b21e-47b8-8f70-bd3ea024ad5d} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Query memory tracker: fault injected. Would use 1.01 MiB (attempt to allocate chunk of 1.01 MiB), maximum: 9.31 GiB. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41754) (comment: 01513_defaults_on_defaults_no_column.sql) (query 10, line 22) (in query: SELECT 1 from defaults_on_defaults where length(`Arr.C4`) = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:11:23.112240 [ 6029 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Query memory tracker: fault injected. Would use 1.01 MiB (attempt to allocate chunk of 1.01 MiB), maximum: 9.31 GiB. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:11:23.292418 [ 10609 ] {b01a6c32-e430-43a5-af6d-f243cd5921bb} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 37, line 54) (in query: SELECT count() FROM datetime_date_table WHERE col_date_lc > '2020-03-04 10:20:45'::DateTime;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:23.460855 [ 10609 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:24.545154 [ 10181 ] {08807fc8-d350-424e-9713-ded9d5597fd1} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 176, line 177) (in query: SELECT anyLastRespectNulls(NULL, NULL, NULL);) 2025.11.13 09:11:24.554873 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:24.581692 [ 10181 ] {2a77cd66-31ef-45f3-a0b8-d06765b8b1b1} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 177, line 178) (in query: SELECT anyLast_respect_nulls(NULL, NULL, NULL);) 2025.11.13 09:11:24.607782 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:24.715297 [ 10181 ] {4f31969b-90d8-47b0-87d0-7d6bb887e4b8} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 178, line 179) (in query: SELECT anyRespectNulls(NULL, NULL, NULL);) 2025.11.13 09:11:24.725047 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:24.774278 [ 10181 ] {34b1fd4e-def7-4425-b1ab-6d1b419d6a28} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 179, line 180) (in query: SELECT anyValueRespectNulls(NULL, NULL, NULL);) 2025.11.13 09:11:24.783506 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:24.840321 [ 10181 ] {3c6fde48-a05f-4c6f-b4a1-c63115176ace} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 180, line 181) (in query: SELECT any_respect_nulls(NULL, NULL, NULL);) 2025.11.13 09:11:24.844548 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:25.119237 [ 10181 ] {bdaff58d-fbc1-40ff-8de6-015145c98c49} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 182, line 183) (in query: SELECT any_value_respect_nulls(NULL, NULL, NULL);) 2025.11.13 09:11:25.127525 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:25.248833 [ 10181 ] {2096a571-17c9-4660-8046-19719cea86ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 183, line 184) (in query: SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL);) 2025.11.13 09:11:25.266787 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:25.287971 [ 16761 ] {30b39718-644b-432a-b921-00e351f6b9b5} ExternalDictionariesLoader: Could not update external dictionary '4638ba79-9d5d-41fa-8223-c926066b36b7', leaving the previous version: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:304: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e965b 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:25.366475 [ 6082 ] {30b39718-644b-432a-b921-00e351f6b9b5} executeQuery: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41706) (comment: 02504_regexp_dictionary_table_source.sql) (query 30, line 71) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:304: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e965b 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:11:25.380110 [ 6082 ] {} TCPHandler: Code: 489. DB::Exception: The regexp tree is cyclical. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:304: DB::RegExpTreeDictionary::initGraph() @ 0x00000000272e965b 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:332: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ea389 6. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 9. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 10. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:11:25.492160 [ 10609 ] {2e473bd7-ce57-4159-b70f-a2f84dd62cf9} executeQuery: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 39, line 56) (in query: SELECT count() FROM datetime_date_table WHERE col_date_lc > '2020-03-04 10:20:45.100'::DateTime64(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1d0e52 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 15. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 16. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:25.497800 [ 10609 ] {} TCPHandler: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1d0e52 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 15. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 16. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:26.422108 [ 10609 ] {f55000d9-c687-4f16-8dd5-b3dedc18a508} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 42, line 60) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_lc > '2020-03-04'::Date;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:26.436510 [ 10609 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, Date because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:26.913037 [ 10609 ] {558899ab-55cf-4a32-907d-bf4319baeb51} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 44, line 62) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_lc > '2020-03-04 10:20:45'::DateTime;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:26.919295 [ 10609 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, DateTime because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000f21c4a0 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1cf2dc 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 15. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 17. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 18. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 19. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:11:27.260433 [ 10609 ] {d3791a8a-895c-4c03-8e26-839f3a080938} executeQuery: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41574) (comment: 02513_date_string_comparison.sql) (query 46, line 64) (in query: SELECT count() FROM datetime_date_table WHERE col_datetime_lc > '2020-03-04 10:20:45.100'::DateTime64(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1d0e52 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 15. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 16. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:27.263925 [ 10609 ] {} TCPHandler: Code: 43. DB::Exception: No operation greater between String and DateTime64(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f1d0e52 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14c8b9 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:49: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003bb186ec 13. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x000000003c13aa28 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000032b94e4a 15. ./build_docker/./src/Planner/Planner.cpp:407: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c0fbc2 16. ./build_docker/./src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf890b 17. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:27.843447 [ 10181 ] {96b971e6-bf2f-474f-82ef-3e57e97a0059} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 200, line 201) (in query: SELECT arrayDistinct(NULL, NULL, NULL);) 2025.11.13 09:11:27.848029 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:27.879504 [ 10181 ] {c0bd251d-2d1a-456d-bdeb-33a4e4a80cf4} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 201, line 202) (in query: SELECT arrayDotProduct(NULL, NULL, NULL);) 2025.11.13 09:11:27.902379 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:27.985667 [ 10181 ] {84507941-bed4-45a0-a5e6-0d681d7346a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 202, line 203) (in query: SELECT arrayElement(NULL, NULL, NULL);) 2025.11.13 09:11:28.007669 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:28.071060 [ 10181 ] {a6ce2a84-f78f-4fda-8f40-fff6e111d4f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 203, line 204) (in query: SELECT arrayElementOrNull(NULL, NULL, NULL);) 2025.11.13 09:11:28.091594 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:28.128885 [ 10181 ] {c3a52ef7-ad13-4532-89c7-4c1635f08a1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 204, line 205) (in query: SELECT arrayEnumerate(NULL, NULL, NULL);) 2025.11.13 09:11:28.135548 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:28.934203 [ 16045 ] {dfe19452-fbbe-45c6-a8b1-c5d265deac73} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48852) (comment: 03033_analyzer_parametrized_view_alias.sql) (in query: DROP DATABASE IF EXISTS test_63zywtz1 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:11:28.990989 [ 16045 ] {dfe19452-fbbe-45c6-a8b1-c5d265deac73} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:30.085395 [ 10181 ] {33ffbebc-7d6e-4523-8fe3-19cf2a743cce} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 215, line 216) (in query: SELECT arrayFlatten(NULL, NULL, NULL);) 2025.11.13 09:11:30.091619 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:30.148113 [ 10181 ] {74d5ae30-3737-4ac5-a5ed-a407b9ac039b} executeQuery: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 216, line 217) (in query: SELECT arrayFold(NULL, NULL, NULL);) 2025.11.13 09:11:30.161007 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:30.367114 [ 10181 ] {02a4d66b-4391-43f7-a251-fae47c2296c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 218, line 219) (in query: SELECT arrayJaccardIndex(NULL, NULL, NULL);) 2025.11.13 09:11:30.380399 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:30.427209 [ 10181 ] {046397be-647a-435c-bad0-cc14d22a45a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 219, line 220) (in query: SELECT arrayJoin(NULL, NULL, NULL);) 2025.11.13 09:11:30.435941 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:31.230140 [ 10181 ] {d68bcee1-4e3e-47ec-a1ab-62fe36610937} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 3, should be 2: In scope SELECT arrayNormalizedGini(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 226, line 227) (in query: SELECT arrayNormalizedGini(NULL, NULL, NULL);) 2025.11.13 09:11:31.237227 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 3, should be 2: In scope SELECT arrayNormalizedGini(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:32.538412 [ 10181 ] {910aa230-026c-43f2-b4be-b4b22f5e9b45} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 231, line 232) (in query: SELECT arrayPopBack(NULL, NULL, NULL);) 2025.11.13 09:11:32.585595 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:32.767626 [ 10181 ] {0b57ee12-6071-4323-9c80-6651f52e1217} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 232, line 233) (in query: SELECT arrayPopFront(NULL, NULL, NULL);) 2025.11.13 09:11:32.775518 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:32.979060 [ 10181 ] {1e616851-ae89-4db6-92b5-c49ce991ba16} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 234, line 235) (in query: SELECT arrayPushBack(NULL, NULL, NULL);) 2025.11.13 09:11:32.983427 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:33.023886 [ 10181 ] {03cd8619-b44d-42e7-97f2-b41506941024} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 235, line 236) (in query: SELECT arrayPushFront(NULL, NULL, NULL);) 2025.11.13 09:11:33.028749 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:33.222279 [ 10181 ] {658c4e7e-790b-4004-abdd-b34db3061e1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 237, line 238) (in query: SELECT arrayRandomSample(NULL, NULL, NULL);) 2025.11.13 09:11:33.227226 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:33.283760 [ 10181 ] {df1bee0a-3eda-4fba-8d15-c06eff473747} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 238, line 239) (in query: SELECT arrayReduce(NULL, NULL, NULL);) 2025.11.13 09:11:33.288492 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:33.334862 [ 3904 ] {d7f1eb87-ac84-4393-9b44-e9ba8da1c065} ExternalDictionariesLoader: Could not update external dictionary '4638ba79-9d5d-41fa-8223-c926066b36b7', leaving the previous version: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:334: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ec54d 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:33.337408 [ 6082 ] {d7f1eb87-ac84-4393-9b44-e9ba8da1c065} executeQuery: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41706) (comment: 02504_regexp_dictionary_table_source.sql) (query 38, line 82) (in query: SYSTEM RELOAD dictionary regexp_dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:334: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ec54d 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:11:33.356380 [ 6082 ] {} TCPHandler: Code: 489. DB::Exception: There are no available regular expression. Please check your config. (INCORRECT_DICTIONARY_DEFINITION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:334: DB::RegExpTreeDictionary::loadData() @ 0x00000000272ec54d 5. ./build_docker/./src/Dictionaries/RegExpTreeDictionary.cpp:432: DB::RegExpTreeDictionary::RegExpTreeDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::RegExpTreeDictionary::Configuration, bool, bool, bool) @ 0x00000000272ef9f3 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x000000002730aa58 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 8. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 10. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 11. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:11:33.592907 [ 10181 ] {43666376-435a-44e5-a763-6a7134cc8be0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayResize'. Expected: Array, got: Nullable(Nothing): In scope SELECT arrayResize(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 240, line 241) (in query: SELECT arrayResize(NULL, NULL, NULL);) 2025.11.13 09:11:33.598062 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayResize'. Expected: Array, got: Nullable(Nothing): In scope SELECT arrayResize(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:33.625284 [ 10181 ] {0581ed53-a7b6-41ec-b9f4-13f972d87bfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 241, line 242) (in query: SELECT arrayReverse(NULL, NULL, NULL);) 2025.11.13 09:11:33.633125 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:34.319782 [ 10181 ] {2eef03f6-f8d3-4a04-bf6e-443193b22c33} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 245, line 246) (in query: SELECT arrayRotateLeft(NULL, NULL, NULL);) 2025.11.13 09:11:34.327782 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:34.360982 [ 10181 ] {e0d46c22-7742-467f-9c9d-cc0902585796} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 246, line 247) (in query: SELECT arrayRotateRight(NULL, NULL, NULL);) 2025.11.13 09:11:34.365625 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:34.575773 [ 10181 ] {3f5feaf2-c461-4891-981a-377d8eb6a199} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 249, line 250) (in query: SELECT arrayShingles(NULL, NULL, NULL);) 2025.11.13 09:11:34.580781 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:35.203226 [ 18112 ] {79316a73-9f5e-4c60-be44-f522756da3ac} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed: While processing SELECT id FROM `03161_table` WHERE f AND ((NOT f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52702) (comment: 03161_cnf_reduction.sql) (query 5, line 9) (in query: EXPLAIN SYNTAX SELECT id FROM 03161_table WHERE f AND (NOT(f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:41: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000032da638d 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:3329: DB::InterpreterSelectQuery::initSettings() @ 0x0000000032b2c306 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:521: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b12083 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:486: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b104ae 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:303: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b0fd18 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000032a9749d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97ef6 15. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 16. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 17. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000032a8314d 18. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000032a7c4c4 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:35.336993 [ 18112 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed: While processing SELECT id FROM `03161_table` WHERE f AND ((NOT f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:41: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000032da638d 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:3329: DB::InterpreterSelectQuery::initSettings() @ 0x0000000032b2c306 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:521: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b12083 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:486: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b104ae 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:303: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b0fd18 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000032a9749d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97ef6 15. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 16. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 17. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000032a8314d 18. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000032a7c4c4 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:35.652885 [ 10181 ] {d750a14d-0a8c-442c-aefb-3e0725464a8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 259, line 260) (in query: SELECT arrayWithConstant(NULL, NULL, NULL);) 2025.11.13 09:11:35.666350 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:35.852245 [ 16109 ] {7439e8aa-776c-40d7-b142-8e6ee9c80239} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45856) (comment: 03161_cnf_reduction.sql) (in query: DROP DATABASE IF EXISTS test_ijxrcvp0 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:11:35.858568 [ 16109 ] {7439e8aa-776c-40d7-b142-8e6ee9c80239} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:36.410281 [ 10181 ] {2e2bf7e9-aee9-416f-abcf-4b823830b7dd} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 263, line 264) (in query: SELECT array_concat_agg(NULL, NULL, NULL);) 2025.11.13 09:11:36.417548 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:36.447351 [ 10181 ] {19a54b56-524e-4ee7-94d5-ae9910c5d90b} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 264, line 265) (in query: SELECT ascii(NULL, NULL, NULL);) 2025.11.13 09:11:36.453286 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:36.497478 [ 10181 ] {fd18a60e-1690-4153-8fb7-574a2a8a4d21} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 265, line 266) (in query: SELECT asin(NULL, NULL, NULL);) 2025.11.13 09:11:36.503170 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:36.585658 [ 10181 ] {4cff3be4-3ab0-4ff4-b211-d9fd09320429} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 266, line 267) (in query: SELECT asinh(NULL, NULL, NULL);) 2025.11.13 09:11:36.591845 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:36.660482 [ 10181 ] {980078ff-4b88-4ab1-82ef-8aa657edff8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 267, line 268) (in query: SELECT assumeNotNull(NULL, NULL, NULL);) 2025.11.13 09:11:36.671093 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:36.732999 [ 10181 ] {934d41e4-8453-4f2c-9229-447bcb5b0503} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 268, line 269) (in query: SELECT atan(NULL, NULL, NULL);) 2025.11.13 09:11:36.742578 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:36.781370 [ 10181 ] {5fd4f52e-8ff2-4dfa-9d8c-2319a4e29442} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 269, line 270) (in query: SELECT atan2(NULL, NULL, NULL);) 2025.11.13 09:11:36.786004 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:36.962452 [ 10181 ] {d3988d53-2071-45ce-9ce5-8a0538c073b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 270, line 271) (in query: SELECT atanh(NULL, NULL, NULL);) 2025.11.13 09:11:36.968602 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:37.018626 [ 10181 ] {2b151335-533a-4498-8b94-d3a1dc6cee31} executeQuery: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 271, line 272) (in query: SELECT authUser(NULL, NULL, NULL);) 2025.11.13 09:11:37.024021 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:37.173384 [ 10181 ] {1fac8fd4-8a26-448f-b6e3-2b7d99a213e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authenticatedUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 272, line 273) (in query: SELECT authenticatedUser(NULL, NULL, NULL);) 2025.11.13 09:11:37.270989 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authenticatedUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:37.695850 [ 17209 ] {7accd640-8cc7-4cce-b233-539faf3399d2} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52764) (comment: 03257_reverse_sorting_key_zookeeper.sql) (query 3, line 6) (in query: create table x1 (i Nullable(int)) engine ReplicatedMergeTree('/clickhouse/tables/{database}/x1', 'r1') order by i desc settings allow_nullable_key = 1, index_granularity = 2, index_granularity_bytes = 10000, allow_experimental_reverse_key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:11:37.715990 [ 17209 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:11:37.736536 [ 10181 ] {1ee06b3f-4752-438d-a81d-c2f665d885dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 276, line 277) (in query: SELECT base58Decode(NULL, NULL, NULL);) 2025.11.13 09:11:37.745152 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:37.787449 [ 10181 ] {8f9fc00b-6807-421a-9b37-a8de21786ea3} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 277, line 278) (in query: SELECT base58Encode(NULL, NULL, NULL);) 2025.11.13 09:11:37.807501 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:37.849792 [ 10181 ] {6d334938-2295-4ff2-a5a0-59513b176c5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 278, line 279) (in query: SELECT base64Decode(NULL, NULL, NULL);) 2025.11.13 09:11:37.856397 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:37.901882 [ 10181 ] {79f8e0fe-254d-4548-99c4-d2eada44f5f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 279, line 280) (in query: SELECT base64Encode(NULL, NULL, NULL);) 2025.11.13 09:11:37.914495 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:37.958370 [ 10181 ] {aa0c5ced-3aa8-4d44-8139-a4029fb16ad9} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 280, line 281) (in query: SELECT base64URLDecode(NULL, NULL, NULL);) 2025.11.13 09:11:37.963982 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:38.053672 [ 10181 ] {f5d87503-749c-4557-adac-36e235d9bcd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 281, line 282) (in query: SELECT base64URLEncode(NULL, NULL, NULL);) 2025.11.13 09:11:38.136644 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:38.202946 [ 10181 ] {4de2cdaf-4f6c-4e58-8cd0-c80a75c0e967} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 282, line 283) (in query: SELECT basename(NULL, NULL, NULL);) 2025.11.13 09:11:38.208433 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:38.337987 [ 10181 ] {b904ca50-dad2-490a-ae2e-4cee17c2e139} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 283, line 284) (in query: SELECT bin(NULL, NULL, NULL);) 2025.11.13 09:11:38.439796 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:38.501841 [ 10181 ] {53e2cf0e-a6fa-42d6-916a-0fa85f79200c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 284, line 285) (in query: SELECT bitAnd(NULL, NULL, NULL);) 2025.11.13 09:11:38.507037 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:38.561163 [ 10181 ] {b80e4bcf-7d94-4226-a65d-8715c02ea084} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 285, line 286) (in query: SELECT bitCount(NULL, NULL, NULL);) 2025.11.13 09:11:38.567603 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:38.677377 [ 10181 ] {e29b3a55-b3a5-4dbb-9cf4-246e0e0030d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 286, line 287) (in query: SELECT bitHammingDistance(NULL, NULL, NULL);) 2025.11.13 09:11:38.681806 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:38.740812 [ 10181 ] {d2acee51-0445-4eca-8007-d43ee240b713} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 287, line 288) (in query: SELECT bitNot(NULL, NULL, NULL);) 2025.11.13 09:11:38.745350 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:38.748198 [ 16206 ] {75d4985d-2ba2-4292-86b9-3f85c74d79c5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53496) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT RowBinary ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:15: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b70f020 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:165: DB::IOutputFormat::work() @ 0x000000003b2261ea 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:38.760338 [ 16206 ] {75d4985d-2ba2-4292-86b9-3f85c74d79c5} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:15: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b70f020 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:165: DB::IOutputFormat::work() @ 0x000000003b2261ea 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:38.786877 [ 10181 ] {5259a270-b7eb-4fce-af55-20d97e1db1ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 288, line 289) (in query: SELECT bitOr(NULL, NULL, NULL);) 2025.11.13 09:11:38.833754 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:38.863987 [ 10181 ] {293865e9-1045-4de9-8b8a-462ec407ae7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 289, line 290) (in query: SELECT bitPositionsToArray(NULL, NULL, NULL);) 2025.11.13 09:11:38.890333 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:38.925952 [ 10181 ] {01d82c17-ea1d-48af-84be-52b9d6fe5c29} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 290, line 291) (in query: SELECT bitRotateLeft(NULL, NULL, NULL);) 2025.11.13 09:11:38.961940 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:39.080447 [ 10181 ] {45b470fc-ea43-41e1-b082-8f2b4f15681e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 291, line 292) (in query: SELECT bitRotateRight(NULL, NULL, NULL);) 2025.11.13 09:11:39.107380 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:39.191491 [ 10181 ] {1657240d-50cf-4920-b16f-309af41263ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 292, line 293) (in query: SELECT bitShiftLeft(NULL, NULL, NULL);) 2025.11.13 09:11:39.198570 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:39.261353 [ 10181 ] {9322aa16-52d2-49a3-8b02-86d6d51d2e8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 293, line 294) (in query: SELECT bitShiftRight(NULL, NULL, NULL);) 2025.11.13 09:11:39.273811 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:39.526186 [ 10181 ] {e7dd57d7-6149-42de-ac34-4baf668adc86} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 295, line 296) (in query: SELECT bitTest(NULL, NULL, NULL);) 2025.11.13 09:11:39.533891 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:39.633638 [ 10609 ] {a905f3da-8247-4d42-a1e7-0400411172c8} executeQuery: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52750) (comment: 01757_optimize_skip_unused_shards_limit.sql) (query 7, line 13) (in query: -- in negative select * from dist_01757 where dummy in (0, 1) settings optimize_skip_unused_shards_limit=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1576: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003845fc28 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003845b3eb 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:901: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c66c19 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:11:39.637960 [ 10609 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1576: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003845fc28 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003845b3eb 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:901: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c66c19 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:11:39.890786 [ 10609 ] {b0ae36bc-df80-4c38-9e98-78ee9162acc2} executeQuery: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52750) (comment: 01757_optimize_skip_unused_shards_limit.sql) (query 8, line 16) (in query: -- or negative select * from dist_01757 where dummy = 0 or dummy = 1 settings optimize_skip_unused_shards_limit=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1576: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003845fc28 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003845b3eb 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:901: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c66c19 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:11:39.900930 [ 10609 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key dummy is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1576: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003845fc28 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003845b3eb 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:901: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c66c19 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:11:39.969174 [ 10181 ] {445ebc8b-8a09-4c33-8682-1b8f11de9fc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 298, line 299) (in query: SELECT bitXor(NULL, NULL, NULL);) 2025.11.13 09:11:39.973822 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:40.012823 [ 16206 ] {4cfd8b72-a72d-4222-9853-55a5c8c69045} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56568) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT JSONStrings ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b71447d 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b22527f 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:40.039352 [ 10181 ] {428a14d8-476e-4f61-88c9-bb93bd4a9d07} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 299, line 300) (in query: SELECT bitmapAnd(NULL, NULL, NULL);) 2025.11.13 09:11:40.048112 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:40.133277 [ 10181 ] {9a357df2-20d8-413f-bd2c-785a268cc972} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 300, line 301) (in query: SELECT bitmapAndCardinality(NULL, NULL, NULL);) 2025.11.13 09:11:40.143896 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:40.235625 [ 10181 ] {2d3170f4-4f98-4c1b-bc49-b758df477e87} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 301, line 302) (in query: SELECT bitmapAndnot(NULL, NULL, NULL);) 2025.11.13 09:11:40.245479 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:40.315636 [ 10181 ] {3b0d2b72-b9da-4e1f-a739-c4e91d132b27} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 302, line 303) (in query: SELECT bitmapAndnotCardinality(NULL, NULL, NULL);) 2025.11.13 09:11:40.333096 [ 16206 ] {4cfd8b72-a72d-4222-9853-55a5c8c69045} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000003b71447d 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x000000003b22527f 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:40.358113 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:40.427287 [ 10181 ] {5fb2dc9d-0dd7-4ca7-b36e-c36443e5d0b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 303, line 304) (in query: SELECT bitmapBuild(NULL, NULL, NULL);) 2025.11.13 09:11:40.561909 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:40.671220 [ 10181 ] {1e3571fe-1ef0-4aa5-b1f9-a932396222e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 304, line 305) (in query: SELECT bitmapCardinality(NULL, NULL, NULL);) 2025.11.13 09:11:41.096265 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:41.130824 [ 10181 ] {17a383e3-a6db-4358-99b5-def0d098c913} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 305, line 306) (in query: SELECT bitmapContains(NULL, NULL, NULL);) 2025.11.13 09:11:41.441699 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:41.494334 [ 10181 ] {264505cf-5fc6-4fe9-bb71-67eb473c8a6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 306, line 307) (in query: SELECT bitmapHasAll(NULL, NULL, NULL);) 2025.11.13 09:11:41.498803 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:41.538452 [ 10181 ] {c4823a75-f24f-486b-a669-2c9b2736575d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 307, line 308) (in query: SELECT bitmapHasAny(NULL, NULL, NULL);) 2025.11.13 09:11:41.545566 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:41.582554 [ 10609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:11:41.582953 [ 10609 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:11:41.589185 [ 10181 ] {440e0ad7-679f-4aaf-9fdb-fb36076a5d4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 308, line 309) (in query: SELECT bitmapMax(NULL, NULL, NULL);) 2025.11.13 09:11:41.593952 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:41.657128 [ 10181 ] {70524969-2eb1-4e1f-89fd-0bf515d4917b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 309, line 310) (in query: SELECT bitmapMin(NULL, NULL, NULL);) 2025.11.13 09:11:41.661976 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:41.697867 [ 10181 ] {68b53bd0-21d9-43f5-94d8-e9fbf117fdd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 310, line 311) (in query: SELECT bitmapOr(NULL, NULL, NULL);) 2025.11.13 09:11:41.702777 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:41.731395 [ 10181 ] {7303acf3-b013-42f3-a96b-ffd9ac6b0467} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 311, line 312) (in query: SELECT bitmapOrCardinality(NULL, NULL, NULL);) 2025.11.13 09:11:41.736587 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:42.139053 [ 10181 ] {1021bba4-98a5-454e-ae59-465ba947b44f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 314, line 315) (in query: SELECT bitmapToArray(NULL, NULL, NULL);) 2025.11.13 09:11:42.143925 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:42.308631 [ 10181 ] {8bad6410-088a-46a8-b54a-e849648a2ae2} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 316, line 317) (in query: SELECT bitmapXor(NULL, NULL, NULL);) 2025.11.13 09:11:42.316983 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:42.438509 [ 10181 ] {66a5da7f-08b4-48b3-9207-974ccb16d52a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 317, line 318) (in query: SELECT bitmapXorCardinality(NULL, NULL, NULL);) 2025.11.13 09:11:42.461489 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:42.548837 [ 10181 ] {e782bb57-b3d2-4f62-a1ad-72a69289bcbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 318, line 319) (in query: SELECT bitmaskToArray(NULL, NULL, NULL);) 2025.11.13 09:11:42.578451 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:42.761405 [ 10181 ] {3aa0ca04-b37e-4106-98c2-24e3e4a80582} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 319, line 320) (in query: SELECT bitmaskToList(NULL, NULL, NULL);) 2025.11.13 09:11:42.817542 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:42.916796 [ 10181 ] {ad3c456e-3362-4296-99e1-c6cf11e813a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 320, line 321) (in query: SELECT blockNumber(NULL, NULL, NULL);) 2025.11.13 09:11:42.949877 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:43.114677 [ 17674 ] {e4dabf9a-b61e-4f5b-8099-f6bb956356b2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1149, jobs=908). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58810) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT JSON ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003afc6559 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:105: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003afc5539 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ParallelFormattingOutputFormat* std::construct_at[abi:ne190107](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003afc3e7d 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003afa73fa 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1847: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000033842658 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:11:43.305002 [ 17674 ] {e4dabf9a-b61e-4f5b-8099-f6bb956356b2} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1149, jobs=908). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params)::'lambda'()&&) @ 0x000000003afc6559 7. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:105: DB::ParallelFormattingOutputFormat::ParallelFormattingOutputFormat(DB::ParallelFormattingOutputFormat::Params) @ 0x000000003afc5539 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ParallelFormattingOutputFormat* std::construct_at[abi:ne190107](DB::ParallelFormattingOutputFormat*, DB::ParallelFormattingOutputFormat::Params&) @ 0x000000003afc3e7d 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003afa73fa 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1847: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000033842658 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:43.512838 [ 10181 ] {46695d46-5454-4380-aa3f-e863331eba7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 322, line 323) (in query: SELECT blockSize(NULL, NULL, NULL);) 2025.11.13 09:11:43.519168 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:43.632435 [ 10181 ] {c2fe8820-4514-476c-bef4-bd4ef1b7262a} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 324, line 325) (in query: SELECT buildId(NULL, NULL, NULL);) 2025.11.13 09:11:43.717898 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:43.748993 [ 10181 ] {f3d62b6f-7f01-456f-8143-c8373fa2c1f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 325, line 326) (in query: SELECT byteHammingDistance(NULL, NULL, NULL);) 2025.11.13 09:11:43.753567 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:43.974682 [ 10181 ] {9569f9e0-632f-4ff8-b7c4-3f2bd30a4fc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 328, line 329) (in query: SELECT byteSwap(NULL, NULL, NULL);) 2025.11.13 09:11:43.981235 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:44.622253 [ 10181 ] {cf3b2fdb-3df5-4456-a397-bf491dd88e0d} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 333, line 334) (in query: SELECT catboostEvaluate(NULL, NULL, NULL);) 2025.11.13 09:11:44.627008 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:44.681052 [ 10181 ] {fa8ccb13-0044-4529-9607-d1ea1486e4f4} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 334, line 335) (in query: SELECT categoricalInformationValue(NULL, NULL, NULL);) 2025.11.13 09:11:44.687852 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:44.726553 [ 10181 ] {4a1eeac9-3a7b-45bd-93e3-ee6e7bfc876e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 335, line 336) (in query: SELECT cbrt(NULL, NULL, NULL);) 2025.11.13 09:11:44.731733 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:45.074221 [ 10181 ] {2eaf02a4-e788-4530-9a52-e5a0870cf18e} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 338, line 339) (in query: SELECT changeDay(NULL, NULL, NULL);) 2025.11.13 09:11:45.079496 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:45.108995 [ 16186 ] {ae5ede70-b57f-486d-8f91-dcf760ab5902} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58314) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT JSON ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b715767 9. ./src/Processors/Formats/IOutputFormat.h:125: DB::IOutputFormat::work() @ 0x000000003b225682 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:45.123921 [ 10181 ] {011ca142-3691-485a-9116-db998285bdcf} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 339, line 340) (in query: SELECT changeHour(NULL, NULL, NULL);) 2025.11.13 09:11:45.128818 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:45.151106 [ 16186 ] {ae5ede70-b57f-486d-8f91-dcf760ab5902} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b715767 9. ./src/Processors/Formats/IOutputFormat.h:125: DB::IOutputFormat::work() @ 0x000000003b225682 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:45.253109 [ 10181 ] {6d7109c6-b246-410c-82de-3edadf135c73} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 340, line 341) (in query: SELECT changeMinute(NULL, NULL, NULL);) 2025.11.13 09:11:45.266500 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:45.309858 [ 10181 ] {b2e747d0-e8bc-4880-8883-2bb7be58842b} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 341, line 342) (in query: SELECT changeMonth(NULL, NULL, NULL);) 2025.11.13 09:11:45.315138 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:45.360292 [ 10181 ] {b7061079-28fb-4f78-8c19-688c738b0981} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 342, line 343) (in query: SELECT changeSecond(NULL, NULL, NULL);) 2025.11.13 09:11:45.364308 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:45.392546 [ 10181 ] {83a986c8-9725-47c5-abeb-4838a252ab72} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 343, line 344) (in query: SELECT changeYear(NULL, NULL, NULL);) 2025.11.13 09:11:45.408031 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:45.529989 [ 6023 ] {e1a2bab2-8f8d-4c42-b174-70c1815afff3} executeQuery: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Timeout exceeded while reading from socket (socket (127.0.0.2:9000), receive timeout 10000 ms) Code: 209. DB::NetException: Timeout exceeded while reading from socket (peer: 127.0.0.2:9000, local: 127.0.0.1:44548, 10000 ms): (127.0.0.2:9000, local address: 127.0.0.1:44548). (SOCKET_TIMEOUT) (version 25.3.8.10072.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout exceeded while reading from socket (peer: 127.0.0.2:9000, local: 127.0.0.1:42464, 10000 ms): (127.0.0.2:9000, local address: 127.0.0.1:42464). (SOCKET_TIMEOUT) (version 25.3.8.10072.altinitytest (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41638) (comment: 01119_session_log.sh) (query 5, line 6) (in query: SELECT * FROM remote('127.0.0.2', system, one, ' INTERSERVER SECRET ', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038f2f976 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038f2a898 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000266ee609 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ecab9 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 7. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:45.535368 [ 6023 ] {} TCPHandler: Code: 519. DB::NetException: All attempts to get table structure failed. Log: Code: 279. DB::NetException: All connection tries failed. Log: Timeout exceeded while reading from socket (socket (127.0.0.2:9000), receive timeout 10000 ms) Code: 209. DB::NetException: Timeout exceeded while reading from socket (peer: 127.0.0.2:9000, local: 127.0.0.1:44548, 10000 ms): (127.0.0.2:9000, local address: 127.0.0.1:44548). (SOCKET_TIMEOUT) (version 25.3.8.10072.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout exceeded while reading from socket (peer: 127.0.0.2:9000, local: 127.0.0.1:42464, 10000 ms): (127.0.0.2:9000, local address: 127.0.0.1:42464). (SOCKET_TIMEOUT) (version 25.3.8.10072.altinitytest (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000038f2f976 3. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038f2a898 4. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000266ee609 5. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ecab9 6. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 7. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:11:46.457937 [ 18389 ] {b89f8a9e-de2a-41e0-98c4-23f4214d5aca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60854) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b715767 9. ./src/Processors/Formats/IOutputFormat.h:125: DB::IOutputFormat::work() @ 0x000000003b225682 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:46.815596 [ 19193 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: : Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:46.816146 [ 19193 ] {} ServerErrorHandler: Code: 516. DB::Exception: : Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:46.854284 [ 6023 ] {0bf31b8a-9247-45c4-b92f-602037890a5c} executeQuery: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: : Authentication failed: password is incorrect, or there is no user with such name.. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 . (AUTHENTICATION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41638) (comment: 01119_session_log.sh) (query 7, line 8) (in query: SELECT * FROM remote('127.0.0.2', system, one, ' ', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x000000003aa7f26f 5. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa76083 6. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 7. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:11:46.892518 [ 6023 ] {} TCPHandler: Code: 516. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: : Authentication failed: password is incorrect, or there is no user with such name.. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:576: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x000000003aa7f26f 5. ./build_docker/./src/Client/Connection.cpp:234: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa76083 6. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 7. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 8. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 9. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 10. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:11:46.945285 [ 18389 ] {b89f8a9e-de2a-41e0-98c4-23f4214d5aca} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b715767 9. ./src/Processors/Formats/IOutputFormat.h:125: DB::IOutputFormat::work() @ 0x000000003b225682 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:47.487142 [ 10181 ] {705e6e42-7980-43fd-bdd8-6b6c6c28c80c} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 354, line 355) (in query: SELECT connectionId(NULL, NULL, NULL);) 2025.11.13 09:11:47.485149 [ 16920 ] {b3b49b11-b035-43e2-89d2-9275057fef40} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60652) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b715767 9. ./src/Processors/Formats/IOutputFormat.h:125: DB::IOutputFormat::work() @ 0x000000003b225682 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:47.493118 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:47.516753 [ 16920 ] {b3b49b11-b035-43e2-89d2-9275057fef40} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b715767 9. ./src/Processors/Formats/IOutputFormat.h:125: DB::IOutputFormat::work() @ 0x000000003b225682 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:47.543003 [ 10181 ] {41987c0c-9290-4c80-bff6-95070cf66d5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 355, line 356) (in query: SELECT connection_id(NULL, NULL, NULL);) 2025.11.13 09:11:47.548892 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:48.110517 [ 10181 ] {246647dd-6e8f-40ca-a6d7-85a3022ce5c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 361, line 362) (in query: SELECT cos(NULL, NULL, NULL);) 2025.11.13 09:11:48.115059 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:48.184459 [ 10181 ] {aa41e4d8-4586-4b95-bb1f-1524f43c310c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 362, line 363) (in query: SELECT cosh(NULL, NULL, NULL);) 2025.11.13 09:11:48.197818 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:48.246040 [ 10181 ] {135f17bd-76b7-4809-9628-3d8d453ac78f} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 363, line 364) (in query: SELECT cosineDistance(NULL, NULL, NULL);) 2025.11.13 09:11:48.251685 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:48.300598 [ 10181 ] {aa3fd99f-ab70-472e-91af-5155f321ce6b} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 364, line 365) (in query: SELECT count(NULL, NULL, NULL);) 2025.11.13 09:11:48.305449 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:48.348295 [ 10181 ] {12bbe7ee-8cae-4e4d-aace-2f6b79c69a29} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 365, line 366) (in query: SELECT countDigits(NULL, NULL, NULL);) 2025.11.13 09:11:48.358125 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:48.425628 [ 10181 ] {ec505183-665f-4ac9-8f52-01250e71f0ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 366, line 367) (in query: SELECT countEqual(NULL, NULL, NULL);) 2025.11.13 09:11:48.456841 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:48.488383 [ 10181 ] {46d8c233-4108-4a23-b276-9af014334744} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 367, line 368) (in query: SELECT countMatches(NULL, NULL, NULL);) 2025.11.13 09:11:48.493350 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:48.540663 [ 10181 ] {a7e9f9f1-5a2e-4d64-acfe-3f9291f51c5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 368, line 369) (in query: SELECT countMatchesCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:11:48.550309 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:49.569023 [ 16194 ] {dca2f980-72f2-4d43-b070-ad15ed8e01a3} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53188) (comment: 02886_missed_json_subcolumns.sql) (query 2, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:11:49.647513 [ 16194 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:11:49.948101 [ 17388 ] {2fb226da-b542-4a81-867b-9e10663aa136} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33780) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT Values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:125: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b715404 9. ./src/Processors/Formats/IOutputFormat.h:103: DB::IOutputFormat::work() @ 0x000000003b224ff5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:50.020391 [ 17388 ] {2fb226da-b542-4a81-867b-9e10663aa136} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:125: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b715404 9. ./src/Processors/Formats/IOutputFormat.h:103: DB::IOutputFormat::work() @ 0x000000003b224ff5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:50.989085 [ 17712 ] {662be08d-f61c-4790-95ab-683cfed207da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34400) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT Values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b715767 9. ./src/Processors/Formats/IOutputFormat.h:125: DB::IOutputFormat::work() @ 0x000000003b225682 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:51.004830 [ 17712 ] {662be08d-f61c-4790-95ab-683cfed207da} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b715767 9. ./src/Processors/Formats/IOutputFormat.h:125: DB::IOutputFormat::work() @ 0x000000003b225682 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:51.376263 [ 10181 ] {bc4bb835-6352-4f48-a136-36091bf9e966} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 380, line 381) (in query: SELECT curdate(NULL, NULL, NULL);) 2025.11.13 09:11:51.381688 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:51.431891 [ 10181 ] {6cf66a09-2af5-47ef-9e6d-9703dcc30cc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 381, line 382) (in query: SELECT currentDatabase(NULL, NULL, NULL);) 2025.11.13 09:11:51.438995 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:51.468695 [ 10181 ] {eed7a80f-88ba-4636-99d3-fcb883b098e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 382, line 383) (in query: SELECT currentProfiles(NULL, NULL, NULL);) 2025.11.13 09:11:51.473691 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:51.545299 [ 10181 ] {ccc65a98-7bbf-4c62-810f-f4a6ace99129} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT currentQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 383, line 384) (in query: SELECT currentQueryID(NULL, NULL, NULL);) 2025.11.13 09:11:51.576556 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT currentQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:51.864943 [ 10181 ] {175bb0e8-ca70-42ba-bf06-b2342aea6225} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 384, line 385) (in query: SELECT currentRoles(NULL, NULL, NULL);) 2025.11.13 09:11:51.871846 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:52.211669 [ 10181 ] {39bba05d-94d9-4016-9532-344c79ccb819} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 385, line 386) (in query: SELECT currentSchemas(NULL, NULL, NULL);) 2025.11.13 09:11:52.235382 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:52.349485 [ 10181 ] {45140f65-eec5-4bcb-b196-c0ca3bf14ef5} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 386, line 387) (in query: SELECT currentUser(NULL, NULL, NULL);) 2025.11.13 09:11:52.370470 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:52.458891 [ 16911 ] {bf920ba5-2f06-472d-93b1-7ca10e1efd2b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58118) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT Vertical ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:125: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b715404 9. ./src/Processors/Formats/IOutputFormat.h:103: DB::IOutputFormat::work() @ 0x000000003b224ff5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:52.479336 [ 10181 ] {80baff16-836b-4d0f-b2ce-ac21da6632df} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 387, line 388) (in query: SELECT current_database(NULL, NULL, NULL);) 2025.11.13 09:11:52.486152 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:52.524951 [ 10181 ] {2a6a8f27-196b-4916-9827-206d53a962ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 388, line 389) (in query: SELECT current_date(NULL, NULL, NULL);) 2025.11.13 09:11:52.525050 [ 16911 ] {bf920ba5-2f06-472d-93b1-7ca10e1efd2b} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:125: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000003b715404 9. ./src/Processors/Formats/IOutputFormat.h:103: DB::IOutputFormat::work() @ 0x000000003b224ff5 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:52.530225 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:52.577626 [ 10181 ] {7806baad-f731-49a5-b47e-1a4bd74d911c} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT current_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 389, line 390) (in query: SELECT current_query_id(NULL, NULL, NULL);) 2025.11.13 09:11:52.583400 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT current_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:52.625254 [ 10181 ] {276b233d-e040-4076-b00b-fa1d5ca5016f} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 390, line 391) (in query: SELECT current_schemas(NULL, NULL, NULL);) 2025.11.13 09:11:52.632414 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:52.677325 [ 10181 ] {a59fe306-4d80-4f01-b513-57d1e4f9adfe} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 391, line 392) (in query: SELECT current_timestamp(NULL, NULL, NULL);) 2025.11.13 09:11:52.682766 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:52.762562 [ 10181 ] {c6940fec-25b9-49e1-ba46-c468e1a2500a} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 392, line 393) (in query: SELECT current_user(NULL, NULL, NULL);) 2025.11.13 09:11:52.775796 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:52.853003 [ 10181 ] {3a40a50d-85fa-4183-8f1a-db465f012ada} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 393, line 394) (in query: SELECT cutFragment(NULL, NULL, NULL);) 2025.11.13 09:11:52.859160 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:52.908939 [ 16195 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:53.041570 [ 16141 ] {e920575d-b89d-47de-a300-9c498a89fd4f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57922) (comment: 02935_http_content_type_with_http_headers_progress.sh/?http_headers_progress_interval_ms=1) (in query: select sleepEachRow(0.01)from numbers(10) FORMAT Vertical ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:15: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b70f020 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:165: DB::IOutputFormat::work() @ 0x000000003b2261ea 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:11:53.065131 [ 16141 ] {e920575d-b89d-47de-a300-9c498a89fd4f} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 7. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 8. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:15: DB::ParallelFormattingOutputFormat::finalizeImpl() @ 0x000000003b70f020 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:165: DB::IOutputFormat::work() @ 0x000000003b2261ea 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 16. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 17. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 18. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:53.179225 [ 10181 ] {0c816271-7b28-4dc1-b40b-17140108d85c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 395, line 396) (in query: SELECT cutQueryString(NULL, NULL, NULL);) 2025.11.13 09:11:53.193959 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.299496 [ 10181 ] {e7882d46-c44c-4f32-a905-b16c4d84c3bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 396, line 397) (in query: SELECT cutQueryStringAndFragment(NULL, NULL, NULL);) 2025.11.13 09:11:53.308914 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.366264 [ 10181 ] {cb51c9a5-e52f-4598-8cff-34ed44fd1046} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 397, line 398) (in query: SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL);) 2025.11.13 09:11:53.371343 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.430482 [ 10181 ] {d0e7798b-1952-49d8-9213-b28027cb0975} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 398, line 399) (in query: SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.11.13 09:11:53.442136 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.509383 [ 10181 ] {f47e125a-361b-4897-83f2-6b8c3927128b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 399, line 400) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.11.13 09:11:53.516848 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.650114 [ 10181 ] {71210ffe-5fb3-4679-acca-3a5b37b9868b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 400, line 401) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL);) 2025.11.13 09:11:53.654912 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.711821 [ 10181 ] {c0d17ac6-72f2-4cd2-894a-c43e6e21024e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 401, line 402) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL);) 2025.11.13 09:11:53.716304 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.763452 [ 10181 ] {33e63094-65aa-4587-b43c-17f4f806fcd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 402, line 403) (in query: SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.11.13 09:11:53.769675 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.816625 [ 10181 ] {1659ea2c-f80d-4dce-b798-880cdd4fce7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 403, line 404) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL);) 2025.11.13 09:11:53.837547 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.883770 [ 10181 ] {a91a1131-c9ca-48af-8a36-e809a53a2132} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 404, line 405) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL);) 2025.11.13 09:11:53.902116 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.938811 [ 10181 ] {970e16f4-c010-4a2b-9017-0999cb8ac676} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 405, line 406) (in query: SELECT cutURLParameter(NULL, NULL, NULL);) 2025.11.13 09:11:53.943401 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:53.979008 [ 10181 ] {1b303eba-7590-4bc8-9fc5-cf95235d3f78} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 406, line 407) (in query: SELECT cutWWW(NULL, NULL, NULL);) 2025.11.13 09:11:53.984136 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:54.003725 [ 16195 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:54.019170 [ 10181 ] {b49b0ff9-42f6-43a3-ad69-a633be5d3187} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 407, line 408) (in query: SELECT damerauLevenshteinDistance(NULL, NULL, NULL);) 2025.11.13 09:11:54.030692 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:54.268839 [ 10181 ] {580327c8-493e-4522-9392-f038b18baf2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 410, line 411) (in query: SELECT dateTime64ToSnowflake(NULL, NULL, NULL);) 2025.11.13 09:11:54.273523 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:54.409710 [ 10181 ] {c78d40bc-875d-4099-83cc-0dc2db355bba} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 412, line 413) (in query: SELECT dateTimeToSnowflake(NULL, NULL, NULL);) 2025.11.13 09:11:54.414229 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:54.774854 [ 10181 ] {494c6cb2-8a15-44fe-a361-5e0cd1783daf} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 417, line 418) (in query: SELECT decodeHTMLComponent(NULL, NULL, NULL);) 2025.11.13 09:11:54.782380 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:54.867706 [ 10181 ] {18ae7fec-a5e3-4b4a-b64b-926cc874dec2} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 418, line 419) (in query: SELECT decodeURLComponent(NULL, NULL, NULL);) 2025.11.13 09:11:54.872045 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:54.905786 [ 10181 ] {37791ac7-c5da-445c-bf0b-ebab6dc78f95} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 419, line 420) (in query: SELECT decodeURLFormComponent(NULL, NULL, NULL);) 2025.11.13 09:11:54.910976 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:54.941888 [ 10181 ] {39d79055-540d-4d8b-b441-cb09798a094c} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 420, line 421) (in query: SELECT decodeXMLComponent(NULL, NULL, NULL);) 2025.11.13 09:11:54.957896 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.045398 [ 10181 ] {558a75c6-eac1-4f5f-8a66-e30d4fb3c66e} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 422, line 423) (in query: SELECT defaultProfiles(NULL, NULL, NULL);) 2025.11.13 09:11:55.053582 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.083775 [ 10181 ] {3e9a0050-a97c-4909-9a3a-ab1fda2337be} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 423, line 424) (in query: SELECT defaultRoles(NULL, NULL, NULL);) 2025.11.13 09:11:55.092391 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.123786 [ 10181 ] {c76a223c-c172-428f-9bbf-e4c4595b4022} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 424, line 425) (in query: SELECT defaultValueOfArgumentType(NULL, NULL, NULL);) 2025.11.13 09:11:55.128950 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.212043 [ 10181 ] {5ce87ec9-7374-4e15-b727-5459c9376498} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 425, line 426) (in query: SELECT defaultValueOfTypeName(NULL, NULL, NULL);) 2025.11.13 09:11:55.217473 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.241218 [ 10181 ] {e847c11d-1793-4a19-8986-d821c2aa3281} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 426, line 427) (in query: SELECT degrees(NULL, NULL, NULL);) 2025.11.13 09:11:55.245279 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.279833 [ 10181 ] {c7609548-23f5-4d0d-b2cc-27e26516526a} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 427, line 428) (in query: SELECT deltaSum(NULL, NULL, NULL);) 2025.11.13 09:11:55.286354 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.307747 [ 18771 ] {f56a7dd5-cff0-4fa0-81fa-c36b3435713f} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 4, line 4) (in query: SELECT BLAKE3(NULL, NULL, NULL);) 2025.11.13 09:11:55.312659 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.327675 [ 10181 ] {033765ef-1f49-452c-96a9-36956105378a} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 428, line 429) (in query: SELECT deltaSumTimestamp(NULL, NULL, NULL);) 2025.11.13 09:11:55.362973 [ 18771 ] {ab9ad557-472d-4d6f-82d9-e8f397f087a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 5, line 6) (in query: SELECT CHARACTER_LENGTH(NULL, NULL, NULL);) 2025.11.13 09:11:55.372211 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.391469 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.407316 [ 18771 ] {10b5d4e4-bd80-43c1-bfa4-19ca82a377f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 6, line 7) (in query: SELECT CHAR_LENGTH(NULL, NULL, NULL);) 2025.11.13 09:11:55.408617 [ 10181 ] {e49cddda-0f9b-475f-83d1-2a554b832110} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 429, line 430) (in query: SELECT demangle(NULL, NULL, NULL);) 2025.11.13 09:11:55.414108 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.467244 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.573639 [ 10181 ] {e9a77346-75bf-449d-aec0-ba58a7a1e3ae} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 430, line 431) (in query: SELECT denseRank(NULL, NULL, NULL);) 2025.11.13 09:11:55.595942 [ 10181 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:11:55.636812 [ 10181 ] {50fb6d2b-749f-4b68-9a16-c2333492b47c} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 431, line 432) (in query: SELECT dense_rank(NULL, NULL, NULL);) 2025.11.13 09:11:55.655014 [ 10181 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:11:55.747299 [ 18771 ] {69b0c9bb-a3ca-467b-b14f-9e5336dacdd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 9, line 10) (in query: SELECT CRC32(NULL, NULL, NULL);) 2025.11.13 09:11:55.753711 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.755250 [ 10181 ] {a58e6b15-af22-47db-8a74-532902e471e1} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 432, line 433) (in query: SELECT detectCharset(NULL, NULL, NULL);) 2025.11.13 09:11:55.761692 [ 10181 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:11:55.789181 [ 10181 ] {137e26c9-e308-429d-a9c6-241010fa0e9c} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 433, line 434) (in query: SELECT detectLanguage(NULL, NULL, NULL);) 2025.11.13 09:11:55.794794 [ 10181 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:11:55.829792 [ 10181 ] {e893edb9-ffee-4f15-b25d-fa5a22a3b8ac} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 434, line 435) (in query: SELECT detectLanguageMixed(NULL, NULL, NULL);) 2025.11.13 09:11:55.834213 [ 10181 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:11:55.856488 [ 18771 ] {e1bc5e40-7519-4e88-97f1-0b040336c7c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 10, line 11) (in query: SELECT CRC32IEEE(NULL, NULL, NULL);) 2025.11.13 09:11:55.861105 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.862978 [ 10181 ] {8bb41eaf-ddc9-4cd6-8966-621fe30a6e96} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 435, line 436) (in query: SELECT detectLanguageUnknown(NULL, NULL, NULL);) 2025.11.13 09:11:55.868164 [ 10181 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:11:55.886791 [ 18771 ] {8e13aa5b-069c-46d7-be40-8f7df7089a2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 11, line 12) (in query: SELECT CRC64(NULL, NULL, NULL);) 2025.11.13 09:11:55.892284 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.916455 [ 10181 ] {efa4b094-7602-4a34-900d-873bfe9f616e} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 436, line 437) (in query: SELECT detectProgrammingLanguage(NULL, NULL, NULL);) 2025.11.13 09:11:55.921940 [ 6023 ] {0cf604f6-753f-443e-8e9e-aaba3aaaad06} executeQuery: Code: 86. DB::Exception: Received error from remote server http://127.0.0.1:8123/?query=select+1&user=default&password=wrong. HTTP status code: 401 'Unauthorized', body length: 669 bytes, body: 'Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD) (version 25.3.8.10072.altinitytest (altinity build)) ': (in file/uri http://127.0.0.1:8123/?query=select+1&user=default&password=wrong): While executing LineAsStringRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41638) (comment: 01119_session_log.sh) (query 9, line 11) (in query: select * from url('http://127.0.0.1:8123/?query=select+1&user=default&password=wrong', LineAsString, 's String');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020232719 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020232097 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000267dc64a 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000267dcafc 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000267de4b8 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000267e5767 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000267d74c2 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000267e1c32 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5fa133 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 21. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x0000000038e5cfa6 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:11:55.923030 [ 18771 ] {3b552594-71cf-44f5-bc81-1055469d20a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 12, line 13) (in query: SELECT DATABASE(NULL, NULL, NULL);) 2025.11.13 09:11:55.923151 [ 10181 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:11:55.928951 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:55.939084 [ 6023 ] {} TCPHandler: Code: 86. DB::Exception: Received error from remote server http://127.0.0.1:8123/?query=select+1&user=default&password=wrong. HTTP status code: 401 'Unauthorized', body length: 669 bytes, body: 'Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD) (version 25.3.8.10072.altinitytest (altinity build)) ': (in file/uri http://127.0.0.1:8123/?query=select+1&user=default&password=wrong): While executing LineAsStringRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020232719 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020232097 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000267dc64a 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000267dcafc 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000267de4b8 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000267e5767 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000267d74c2 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000267e1c32 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5fa133 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 21. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x0000000038e5cfa6 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:11:55.965955 [ 10181 ] {5c263021-2024-4f7a-a7dd-364f21207479} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 437, line 438) (in query: SELECT detectTonality(NULL, NULL, NULL);) 2025.11.13 09:11:55.980984 [ 10181 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:11:55.998879 [ 10181 ] {848da524-83bd-43e9-8bc0-016b80cf0ef0} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 438, line 439) (in query: SELECT dictGet(NULL, NULL, NULL);) 2025.11.13 09:11:56.008522 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:56.095564 [ 10181 ] {6ee275b6-4e17-40ba-a6f3-47f903fc29f1} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 439, line 440) (in query: SELECT dictGetAll(NULL, NULL, NULL);) 2025.11.13 09:11:56.100959 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:56.133034 [ 10181 ] {1e9f342c-ebfb-48cc-971f-2db7934b714b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 440, line 441) (in query: SELECT dictGetChildren(NULL, NULL, NULL);) 2025.11.13 09:11:56.140315 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:56.435079 [ 10181 ] {8fe2960d-49e6-42d4-a235-6089f4d887cf} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 445, line 446) (in query: SELECT dictGetDescendants(NULL, NULL, NULL);) 2025.11.13 09:11:56.440598 [ 10181 ] {} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) 2025.11.13 09:11:56.633507 [ 18771 ] {c99d0f08-c7bc-478d-baf1-8b344e4aad8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 21, line 22) (in query: SELECT FORMAT_BYTES(NULL, NULL, NULL);) 2025.11.13 09:11:56.650716 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:56.685249 [ 18771 ] {d2da33f3-cc37-4b67-9402-878a8b3e0095} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 22, line 23) (in query: SELECT FQDN(NULL, NULL, NULL);) 2025.11.13 09:11:56.698254 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:56.715622 [ 18771 ] {9071fc85-b470-4244-964b-85b651a9577f} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 23, line 24) (in query: SELECT FROM_BASE64(NULL, NULL, NULL);) 2025.11.13 09:11:56.732169 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:56.740584 [ 10181 ] {956ec9d3-6726-4771-bc02-a32b04fc5da1} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 450, line 451) (in query: SELECT dictGetHierarchy(NULL, NULL, NULL);) 2025.11.13 09:11:56.746343 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:56.751961 [ 18771 ] {3263fa9f-3ff2-4523-ac90-38f6258a7152} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 24, line 25) (in query: SELECT FROM_DAYS(NULL, NULL, NULL);) 2025.11.13 09:11:56.758051 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:56.888714 [ 18771 ] {77510261-910d-420a-ab3a-8d1a39688351} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 27, line 28) (in query: SELECT INET6_ATON(NULL, NULL, NULL);) 2025.11.13 09:11:56.893894 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:56.922038 [ 18771 ] {7a058fa1-1413-427e-841d-9a1a3d7736df} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 28, line 29) (in query: SELECT INET6_NTOA(NULL, NULL, NULL);) 2025.11.13 09:11:56.928600 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:56.967357 [ 16195 ] {} DynamicQueryHandler: Code: 516. DB::Exception: nonexistsnt_user_1119: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:56.977817 [ 16195 ] {} DynamicQueryHandler: Code: 516. DB::Exception: nonexistsnt_user_1119: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:56.983525 [ 6023 ] {42066e54-6749-4f2e-8d0e-9bbc9a7519c0} executeQuery: Code: 86. DB::Exception: Received error from remote server http://127.0.0.1:8123/?query=select+1&user=nonexistsnt_user_1119. HTTP status code: 403 'Forbidden', body length: 208 bytes, body: 'Code: 516. DB::Exception: nonexistsnt_user_1119: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) ': (in file/uri http://127.0.0.1:8123/?query=select+1&user=nonexistsnt_user_1119): While executing LineAsStringRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41638) (comment: 01119_session_log.sh) (query 10, line 12) (in query: select * from url('http://127.0.0.1:8123/?query=select+1&user=nonexistsnt_user_1119', LineAsString, 's String');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020232719 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020232097 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000267dc64a 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000267dcafc 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000267de4b8 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000267e5767 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000267d74c2 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000267e1c32 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5fa133 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 21. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x0000000038e5cfa6 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:11:56.989233 [ 6023 ] {} TCPHandler: Code: 86. DB::Exception: Received error from remote server http://127.0.0.1:8123/?query=select+1&user=nonexistsnt_user_1119. HTTP status code: 403 'Forbidden', body length: 208 bytes, body: 'Code: 516. DB::Exception: nonexistsnt_user_1119: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) ': (in file/uri http://127.0.0.1:8123/?query=select+1&user=nonexistsnt_user_1119): While executing LineAsStringRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020232719 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020232097 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000267dc64a 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000267dcafc 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000267de4b8 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000267e5767 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000267d74c2 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000267e1c32 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5fa133 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 21. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x0000000038e5cfa6 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:11:56.993148 [ 18771 ] {6983c60b-edc1-42f9-8187-27c41ec0b860} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 29, line 30) (in query: SELECT INET_ATON(NULL, NULL, NULL);) 2025.11.13 09:11:57.001699 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.023992 [ 18771 ] {7b20bda9-39de-4033-ba08-5830103f9ebf} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 30, line 31) (in query: SELECT INET_NTOA(NULL, NULL, NULL);) 2025.11.13 09:11:57.026195 [ 16195 ] {} DynamicQueryHandler: Code: 516. DB::Exception: INTERSERVER SECRET : Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:57.028936 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.033714 [ 16195 ] {} DynamicQueryHandler: Code: 516. DB::Exception: INTERSERVER SECRET : Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:57.043130 [ 6023 ] {8892e4e2-6a44-44d7-b7a8-439a022b48fc} executeQuery: Code: 86. DB::Exception: Received error from remote server http://127.0.0.1:8123/?query=select+1&user=+INTERSERVER+SECRET+. HTTP status code: 403 'Forbidden', body length: 207 bytes, body: 'Code: 516. DB::Exception: INTERSERVER SECRET : Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) ': (in file/uri http://127.0.0.1:8123/?query=select+1&user=+INTERSERVER+SECRET+): While executing LineAsStringRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41638) (comment: 01119_session_log.sh) (query 11, line 13) (in query: select * from url('http://127.0.0.1:8123/?query=select+1&user=+INTERSERVER+SECRET+', LineAsString, 's String');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020232719 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020232097 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000267dc64a 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000267dcafc 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000267de4b8 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000267e5767 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000267d74c2 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000267e1c32 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5fa133 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 21. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x0000000038e5cfa6 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:11:57.050464 [ 6023 ] {} TCPHandler: Code: 86. DB::Exception: Received error from remote server http://127.0.0.1:8123/?query=select+1&user=+INTERSERVER+SECRET+. HTTP status code: 403 'Forbidden', body length: 207 bytes, body: 'Code: 516. DB::Exception: INTERSERVER SECRET : Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) ': (in file/uri http://127.0.0.1:8123/?query=select+1&user=+INTERSERVER+SECRET+): While executing LineAsStringRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020232719 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020232097 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000267dc64a 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000267dcafc 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000267de4b8 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000267e5767 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000267d74c2 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000267e1c32 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5fa133 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 21. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x0000000038e5cfa6 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:11:57.054474 [ 18771 ] {aa3e2535-4c28-4ab5-8da6-b47657d5d8f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 31, line 32) (in query: SELECT IPv4CIDRToRange(NULL, NULL, NULL);) 2025.11.13 09:11:57.061531 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.084812 [ 18771 ] {8868eeaa-ed76-4fa9-a89e-080551c97c77} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 32, line 33) (in query: SELECT IPv4NumToString(NULL, NULL, NULL);) 2025.11.13 09:11:57.089706 [ 16195 ] {} DynamicQueryHandler: Code: 516. DB::Exception: : Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:57.089876 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.095942 [ 16195 ] {} DynamicQueryHandler: Code: 516. DB::Exception: : Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:57.100309 [ 6023 ] {d388b71c-38ea-4df6-b9f3-ac32dffd12ee} executeQuery: Code: 86. DB::Exception: Received error from remote server http://127.0.0.1:8123/?query=select+1&user=+++. HTTP status code: 403 'Forbidden', body length: 190 bytes, body: 'Code: 516. DB::Exception: : Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) ': (in file/uri http://127.0.0.1:8123/?query=select+1&user=+++): While executing LineAsStringRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41638) (comment: 01119_session_log.sh) (query 12, line 14) (in query: select * from url('http://127.0.0.1:8123/?query=select+1&user=+++', LineAsString, 's String');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020232719 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020232097 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000267dc64a 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000267dcafc 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000267de4b8 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000267e5767 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000267d74c2 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000267e1c32 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5fa133 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 21. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x0000000038e5cfa6 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:11:57.106994 [ 6023 ] {} TCPHandler: Code: 86. DB::Exception: Received error from remote server http://127.0.0.1:8123/?query=select+1&user=+++. HTTP status code: 403 'Forbidden', body length: 190 bytes, body: 'Code: 516. DB::Exception: : Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) ': (in file/uri http://127.0.0.1:8123/?query=select+1&user=+++): While executing LineAsStringRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020232719 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020232097 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000267dc64a 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000267dcafc 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000267de4b8 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000267e5767 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000267d74c2 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000267e1c32 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5fa133 13. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 14. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 15. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 16. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 21. ./build_docker/./src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x0000000038e5cfa6 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:11:57.114490 [ 18771 ] {f2d4fc28-3349-4edd-a851-b86a40411508} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 33, line 34) (in query: SELECT IPv4NumToStringClassC(NULL, NULL, NULL);) 2025.11.13 09:11:57.119804 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.144933 [ 18771 ] {c716b190-2f07-4dd2-afa4-9d4ab98b56ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 34, line 35) (in query: SELECT IPv4StringToNum(NULL, NULL, NULL);) 2025.11.13 09:11:57.149713 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.174501 [ 18771 ] {96e62113-cd43-4771-a30f-4dac582f8f7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 35, line 36) (in query: SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL);) 2025.11.13 09:11:57.187285 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.204479 [ 18771 ] {a6e16917-d778-4d07-a7fd-aeab0c6d469c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 36, line 37) (in query: SELECT IPv4StringToNumOrNull(NULL, NULL, NULL);) 2025.11.13 09:11:57.214059 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.235158 [ 18771 ] {4fec0c87-3dbc-4e53-9ed0-389539bc6f36} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 37, line 38) (in query: SELECT IPv4ToIPv6(NULL, NULL, NULL);) 2025.11.13 09:11:57.242410 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.264392 [ 18771 ] {860db2a2-9dd3-45fd-a716-35312085ad29} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 38, line 39) (in query: SELECT IPv6CIDRToRange(NULL, NULL, NULL);) 2025.11.13 09:11:57.268483 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.293711 [ 18771 ] {ff1c5e15-a9ca-421c-99d4-12afab6beec0} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 39, line 40) (in query: SELECT IPv6NumToString(NULL, NULL, NULL);) 2025.11.13 09:11:57.297773 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.331021 [ 18771 ] {2412e658-9bf1-4675-9ce1-fdd642e469b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 40, line 41) (in query: SELECT IPv6StringToNum(NULL, NULL, NULL);) 2025.11.13 09:11:57.338271 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.369461 [ 18771 ] {965abac0-de1d-4e41-aeaa-7d28220ddb60} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 41, line 42) (in query: SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL);) 2025.11.13 09:11:57.375339 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.404384 [ 18771 ] {265b268d-3ae0-41a1-81a5-34400d7b3b5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 42, line 43) (in query: SELECT IPv6StringToNumOrNull(NULL, NULL, NULL);) 2025.11.13 09:11:57.409316 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.436551 [ 18771 ] {fc17ad2c-98bf-464f-b021-3e89186340a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 43, line 44) (in query: SELECT JSONAllPaths(NULL, NULL, NULL);) 2025.11.13 09:11:57.440789 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.477498 [ 18771 ] {6e96cda0-5f12-453e-a827-9b4396d497d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 44, line 45) (in query: SELECT JSONAllPathsWithTypes(NULL, NULL, NULL);) 2025.11.13 09:11:57.489923 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.507173 [ 18771 ] {b74b50fa-9796-4a45-a79b-c415eb851dec} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 45, line 46) (in query: SELECT JSONArrayLength(NULL, NULL, NULL);) 2025.11.13 09:11:57.512826 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.530952 [ 10211 ] {11178501-519d-4ccd-96d4-c1f693a559f8} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic, see allow_nondeterministic_mutations setting. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57264) (comment: 02842_mutations_replace_non_deterministic.sql) (query 15, line 37) (in query: -- Too big result. ALTER TABLE t_mutations_nondeterministic UPDATE v = (SELECT groupArray(number) FROM numbers(10000)) WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1427: DB::MutationsInterpreter::validate() @ 0x0000000032efb2fc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991c01 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:11:57.535215 [ 10211 ] {} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic, see allow_nondeterministic_mutations setting. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1427: DB::MutationsInterpreter::validate() @ 0x0000000032efb2fc 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991c01 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:11:57.540255 [ 18771 ] {a43dedff-59e0-4d67-a8b0-a3141ef358e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 46, line 47) (in query: SELECT JSONDynamicPaths(NULL, NULL, NULL);) 2025.11.13 09:11:57.548967 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.583663 [ 18771 ] {7603fdae-54d1-4b27-9ae9-80d9089f5d3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 47, line 48) (in query: SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL);) 2025.11.13 09:11:57.611115 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:57.622669 [ 10181 ] {fdbd26f1-e717-4c80-8e84-8f9a0056f6e1} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 463, line 464) (in query: SELECT dictGetOrDefault(NULL, NULL, NULL);) 2025.11.13 09:11:57.628539 [ 18771 ] {b202aba8-c396-4089-aad1-b79e0588e225} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 48, line 49) (in query: SELECT JSONExtract(NULL, NULL, NULL);) 2025.11.13 09:11:57.631335 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:57.634414 [ 18771 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: NULL: In scope SELECT JSONExtract(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.11.13 09:11:57.654923 [ 10181 ] {a14377b7-c0b1-469d-b212-a02dae7edae7} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 464, line 465) (in query: SELECT dictGetOrNull(NULL, NULL, NULL);) 2025.11.13 09:11:57.661729 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:11:57.931382 [ 18771 ] {6394848a-e2c6-472a-896d-5069222d2903} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 54, line 55) (in query: SELECT JSONExtractKeysAndValues(NULL, NULL, NULL);) 2025.11.13 09:11:57.936120 [ 18771 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: NULL: In scope SELECT JSONExtractKeysAndValues(NULL, NULL, NULL). (ILLEGAL_COLUMN) 2025.11.13 09:11:58.269222 [ 16702 ] {ed9b9482-b397-4481-8f81-09515e9cf3d9} executeQuery: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57344) (comment: 01332_join_type_syntax_position.sql) (query 9, line 13) (in query: select * from numbers(1) t1 asof join numbers(1) t2 using number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:225: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbcb44 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::Block const&, bool const&, std::allocator, 0>(std::allocator, std::shared_ptr&, DB::Block const&, bool const&) @ 0x0000000032cf52a5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb4af 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:58.292333 [ 16702 ] {} TCPHandler: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:225: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbcb44 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::Block const&, bool const&, std::allocator, 0>(std::allocator, std::shared_ptr&, DB::Block const&, bool const&) @ 0x0000000032cf52a5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb4af 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:58.329711 [ 16702 ] {266fdb7c-392f-47d2-90ea-4b2d48f06a54} executeQuery: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57344) (comment: 01332_join_type_syntax_position.sql) (query 10, line 14) (in query: select * from numbers(1) t1 left asof join numbers(1) t2 using number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:225: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbcb44 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::Block const&, bool const&, std::allocator, 0>(std::allocator, std::shared_ptr&, DB::Block const&, bool const&) @ 0x0000000032cf52a5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb4af 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:58.333264 [ 16702 ] {} TCPHandler: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:225: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbcb44 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::Block const&, bool const&, std::allocator, 0>(std::allocator, std::shared_ptr&, DB::Block const&, bool const&) @ 0x0000000032cf52a5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb4af 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:58.495182 [ 18771 ] {993d4af7-d41e-4075-bae5-88c70874b788} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 63, line 64) (in query: SELECT JSONSharedDataPaths(NULL, NULL, NULL);) 2025.11.13 09:11:58.507927 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:58.527720 [ 18771 ] {12e9e568-a532-4ae4-9891-b7a780585ae5} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 64, line 65) (in query: SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL);) 2025.11.13 09:11:58.533016 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:58.584256 [ 10181 ] {08464ada-61ee-424a-92ae-1518a0ac8b68} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 479, line 480) (in query: SELECT displayName(NULL, NULL, NULL);) 2025.11.13 09:11:58.588431 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:58.612187 [ 10181 ] {6c41b8d8-0d5f-4b37-aedd-a98ac69ef857} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 480, line 481) (in query: SELECT distanceL1(NULL, NULL, NULL);) 2025.11.13 09:11:58.616388 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:58.645123 [ 10181 ] {62eb1a53-b87d-42b3-a535-ffaaf678fff8} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 481, line 482) (in query: SELECT distanceL2(NULL, NULL, NULL);) 2025.11.13 09:11:58.649649 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:58.675208 [ 10181 ] {2f3efffa-1f34-4b20-b1f5-57cec4035f83} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 482, line 483) (in query: SELECT distanceL2Squared(NULL, NULL, NULL);) 2025.11.13 09:11:58.681432 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:58.762268 [ 10181 ] {0b0841dc-1194-43c7-9a5b-5684644d6e0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 483, line 484) (in query: SELECT distanceLinf(NULL, NULL, NULL);) 2025.11.13 09:11:58.771729 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:58.794609 [ 16702 ] {cf4a55ee-d782-4e58-841b-68c006f89934} executeQuery: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57344) (comment: 01332_join_type_syntax_position.sql) (query 19, line 30) (in query: select * from numbers(1) t1 asof join numbers(1) t2 using number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:225: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbcb44 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::Block const&, bool const&, std::allocator, 0>(std::allocator, std::shared_ptr&, DB::Block const&, bool const&) @ 0x0000000032cf52a5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb4af 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:58.797661 [ 18771 ] {782591b7-b8ef-4913-bc9d-1c70cae0f4f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 66, line 67) (in query: SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL);) 2025.11.13 09:11:58.798389 [ 16702 ] {} TCPHandler: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:225: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbcb44 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::Block const&, bool const&, std::allocator, 0>(std::allocator, std::shared_ptr&, DB::Block const&, bool const&) @ 0x0000000032cf52a5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb4af 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:58.840936 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:58.847790 [ 16702 ] {cdb5235c-9ae8-4ff4-a833-e1c937837774} executeQuery: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57344) (comment: 01332_join_type_syntax_position.sql) (query 20, line 31) (in query: select * from numbers(1) t1 asof left join numbers(1) t2 using number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:225: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbcb44 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::Block const&, bool const&, std::allocator, 0>(std::allocator, std::shared_ptr&, DB::Block const&, bool const&) @ 0x0000000032cf52a5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb4af 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:58.851960 [ 16702 ] {} TCPHandler: Code: 62. DB::Exception: ASOF join needs at least one equi-join column. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:225: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbcb44 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, DB::Block const&, bool const&, std::allocator, 0>(std::allocator, std::shared_ptr&, DB::Block const&, bool const&) @ 0x0000000032cf52a5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb4af 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:11:59.067285 [ 18771 ] {2fdadc79-e32b-43b0-9c64-aa951e122fb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 70, line 71) (in query: SELECT L1Distance(NULL, NULL, NULL);) 2025.11.13 09:11:59.071437 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.083557 [ 10181 ] {73baeeef-ed7f-4433-a91a-5b848ee07726} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 488, line 489) (in query: SELECT divide(NULL, NULL, NULL);) 2025.11.13 09:11:59.089429 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.150773 [ 18771 ] {35d62f73-33b3-4f35-b2a7-bee384efe8fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 71, line 72) (in query: SELECT L1Norm(NULL, NULL, NULL);) 2025.11.13 09:11:59.157268 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.167502 [ 10181 ] {9b419199-809f-46ae-b683-4c5fa7c8f1ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 490, line 491) (in query: SELECT domain(NULL, NULL, NULL);) 2025.11.13 09:11:59.172072 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.181860 [ 18771 ] {5cbcafca-373d-4d5e-989b-88b76a0b0742} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 72, line 73) (in query: SELECT L1Normalize(NULL, NULL, NULL);) 2025.11.13 09:11:59.187139 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.202057 [ 10181 ] {2f62c073-62d1-4fa6-923c-f0715cad6783} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 491, line 492) (in query: SELECT domainRFC(NULL, NULL, NULL);) 2025.11.13 09:11:59.206498 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.218594 [ 18771 ] {4344ab48-d8e9-462f-8ce0-e1db5990304f} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 73, line 74) (in query: SELECT L2Distance(NULL, NULL, NULL);) 2025.11.13 09:11:59.231882 [ 10181 ] {1249919a-8cca-476b-85dd-7f7ac07ea908} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 492, line 493) (in query: SELECT domainWithoutWWW(NULL, NULL, NULL);) 2025.11.13 09:11:59.235195 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.240337 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.250348 [ 18771 ] {b778aa1a-c7ab-4db4-af28-34e0e258980f} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 74, line 75) (in query: SELECT L2Norm(NULL, NULL, NULL);) 2025.11.13 09:11:59.261907 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.267037 [ 10181 ] {9acdaf93-e8f4-417d-8c0e-bcaeddc67c03} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 493, line 494) (in query: SELECT domainWithoutWWWRFC(NULL, NULL, NULL);) 2025.11.13 09:11:59.277723 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.281444 [ 18771 ] {18cc8e1a-7bfc-44d3-8c9b-2dbc501e4c6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 75, line 76) (in query: SELECT L2Normalize(NULL, NULL, NULL);) 2025.11.13 09:11:59.285903 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.311403 [ 18771 ] {d8a93762-ae73-4074-b68e-7212c0cd1d62} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 76, line 77) (in query: SELECT L2SquaredDistance(NULL, NULL, NULL);) 2025.11.13 09:11:59.312609 [ 10181 ] {698c75bd-a3d4-4a09-aef8-6ddbaf06d9b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 494, line 495) (in query: SELECT dotProduct(NULL, NULL, NULL);) 2025.11.13 09:11:59.315981 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.317465 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.343599 [ 10181 ] {8e91bea4-66d8-401e-98ba-870113b1d4bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 495, line 496) (in query: SELECT dumpColumnStructure(NULL, NULL, NULL);) 2025.11.13 09:11:59.344118 [ 18771 ] {5e1293e2-2f48-4bd5-be0a-0ed6b65d04e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 77, line 78) (in query: SELECT L2SquaredNorm(NULL, NULL, NULL);) 2025.11.13 09:11:59.350724 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.392544 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.417458 [ 10181 ] {adedcd0b-72f8-4501-a98b-c8c2924955da} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 496, line 497) (in query: SELECT dynamicElement(NULL, NULL, NULL);) 2025.11.13 09:11:59.425509 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.448782 [ 10181 ] {f5e33678-18dd-4707-bb30-57b667174cde} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 497, line 498) (in query: SELECT dynamicType(NULL, NULL, NULL);) 2025.11.13 09:11:59.452927 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.479195 [ 10181 ] {da486bfc-2e94-4d67-9262-62c41739e1ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 498, line 499) (in query: SELECT e(NULL, NULL, NULL);) 2025.11.13 09:11:59.483394 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.490768 [ 18771 ] {a2c3dc10-51d9-458f-aa8d-d34f4db3a881} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 79, line 80) (in query: SELECT LinfDistance(NULL, NULL, NULL);) 2025.11.13 09:11:59.495406 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.510417 [ 10181 ] {b87322ce-515a-4acc-aed6-5ffd0d311219} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 499, line 500) (in query: SELECT editDistance(NULL, NULL, NULL);) 2025.11.13 09:11:59.522697 [ 18771 ] {d4cf22c3-8d08-4c2d-abc8-48d438dd4e86} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 80, line 81) (in query: SELECT LinfNorm(NULL, NULL, NULL);) 2025.11.13 09:11:59.527377 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.554925 [ 18771 ] {bd1995ab-83d3-4530-a60a-a807617aa842} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 81, line 82) (in query: SELECT LinfNormalize(NULL, NULL, NULL);) 2025.11.13 09:11:59.559198 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.576019 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.602705 [ 10181 ] {f7223ca8-5be4-4559-af10-74b4c515ad88} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 500, line 501) (in query: SELECT editDistanceUTF8(NULL, NULL, NULL);) 2025.11.13 09:11:59.606891 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.631024 [ 18771 ] {c72c5c3b-866d-4280-97c6-4215f5f7b645} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 83, line 84) (in query: SELECT LpNorm(NULL, NULL, NULL);) 2025.11.13 09:11:59.633542 [ 10181 ] {38a6fcf7-8a8b-41ea-8f73-f3f7b2b6d111} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 501, line 502) (in query: SELECT empty(NULL, NULL, NULL);) 2025.11.13 09:11:59.635346 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.642591 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.665164 [ 18771 ] {3cc8439d-78f5-4940-88d4-012be5d6a7dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 84, line 85) (in query: SELECT LpNormalize(NULL, NULL, NULL);) 2025.11.13 09:11:59.665379 [ 10181 ] {8442f948-0c8e-45c5-a323-a7cba9a7cda0} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 502, line 503) (in query: SELECT emptyArrayDate(NULL, NULL, NULL);) 2025.11.13 09:11:59.669793 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.675361 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.693079 [ 10181 ] {78bdeb1d-9d02-47c6-8062-9c5185685ee9} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 503, line 504) (in query: SELECT emptyArrayDateTime(NULL, NULL, NULL);) 2025.11.13 09:11:59.698670 [ 18771 ] {c71ab1cc-7a0b-44d0-b45c-8dd592ebac32} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 85, line 86) (in query: SELECT MACNumToString(NULL, NULL, NULL);) 2025.11.13 09:11:59.700345 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.703774 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.721560 [ 10181 ] {25740cfc-0fdf-441d-84e7-bf8cce5089a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 504, line 505) (in query: SELECT emptyArrayFloat32(NULL, NULL, NULL);) 2025.11.13 09:11:59.735391 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.743163 [ 18771 ] {3cc0f62a-db94-4f07-9127-1cd12d711611} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 86, line 87) (in query: SELECT MACStringToNum(NULL, NULL, NULL);) 2025.11.13 09:11:59.749184 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.752625 [ 10181 ] {ce9fea78-6fcb-4abe-9af5-1245451c076d} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 505, line 506) (in query: SELECT emptyArrayFloat64(NULL, NULL, NULL);) 2025.11.13 09:11:59.757523 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.773018 [ 18771 ] {9dc91820-da1f-47b3-a2a5-a1392510b3e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 87, line 88) (in query: SELECT MACStringToOUI(NULL, NULL, NULL);) 2025.11.13 09:11:59.779039 [ 10181 ] {8a317ccc-0be4-4c7e-af4c-815ec2b582e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 506, line 507) (in query: SELECT emptyArrayInt16(NULL, NULL, NULL);) 2025.11.13 09:11:59.781459 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.784661 [ 3897 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003a3dfd6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003d179be4 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1795: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003d15fa02 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:928: Coordination::ZooKeeper::receiveEvent() @ 0x000000003d15c45b 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:875: Coordination::ZooKeeper::receiveThread() @ 0x000000003d15aaf9 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003d175e4f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:11:59.786571 [ 3505 ] {} test_15.partitioned_table (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:11:59.786655 [ 3497 ] {} test_15.fetches_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:11:59.786677 [ 3512 ] {} test_15.data_rep_02228 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:11:59.786772 [ 3504 ] {} test_1.t_mutations_nondeterministic (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:11:59.786874 [ 3489 ] {} test_15.fetches_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:11:59.787380 [ 3471 ] {} test_9.test_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:11:59.875140 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.877717 [ 18771 ] {205bef3b-393d-453d-b178-2ed134d983f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 88, line 89) (in query: SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL);) 2025.11.13 09:11:59.902848 [ 10181 ] {5394f409-04ca-4267-9d93-672f34103871} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 507, line 508) (in query: SELECT emptyArrayInt32(NULL, NULL, NULL);) 2025.11.13 09:11:59.917667 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.938187 [ 10181 ] {7dc00e39-2ac9-45f6-b47e-dd24f0df96e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 508, line 509) (in query: SELECT emptyArrayInt64(NULL, NULL, NULL);) 2025.11.13 09:11:59.945780 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.965716 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.967899 [ 10181 ] {113ebed4-f115-4a51-8357-3cca4ef29141} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 509, line 510) (in query: SELECT emptyArrayInt8(NULL, NULL, NULL);) 2025.11.13 09:11:59.977716 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:11:59.998792 [ 10181 ] {ef7bfee4-5839-4b80-a54b-14e9219b7074} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 510, line 511) (in query: SELECT emptyArrayString(NULL, NULL, NULL);) 2025.11.13 09:12:00.007533 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.025761 [ 18771 ] {1cfc239f-85a1-42a2-a15d-24f46d7d13ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 89, line 90) (in query: SELECT MD4(NULL, NULL, NULL);) 2025.11.13 09:12:00.031305 [ 10181 ] {769a9d5f-708d-486e-a70c-bf1af719c9c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 511, line 512) (in query: SELECT emptyArrayToSingle(NULL, NULL, NULL);) 2025.11.13 09:12:00.041666 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.113134 [ 18771 ] {01dc7a28-3e1a-4404-95ba-8b892454bf4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 90, line 91) (in query: SELECT MD5(NULL, NULL, NULL);) 2025.11.13 09:12:00.113504 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.129458 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.136938 [ 10181 ] {ad6c0af9-cdf8-4dc7-82fe-4c122750ce4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 512, line 513) (in query: SELECT emptyArrayUInt16(NULL, NULL, NULL);) 2025.11.13 09:12:00.151162 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.166482 [ 10181 ] {5621383c-e3dd-4abc-9db0-1a0362b7352d} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 513, line 514) (in query: SELECT emptyArrayUInt32(NULL, NULL, NULL);) 2025.11.13 09:12:00.174059 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.280677 [ 18771 ] {eb8ed959-0885-44ca-a08e-7c59ab3d5cc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 94, line 95) (in query: SELECT OCTET_LENGTH(NULL, NULL, NULL);) 2025.11.13 09:12:00.287829 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.292299 [ 10181 ] {89aba52f-766f-42a4-beea-86a1dcc9ac5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 514, line 515) (in query: SELECT emptyArrayUInt64(NULL, NULL, NULL);) 2025.11.13 09:12:00.306710 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.321150 [ 10181 ] {bde1bad2-f8b8-437f-87a8-30b57fa2dd5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 515, line 516) (in query: SELECT emptyArrayUInt8(NULL, NULL, NULL);) 2025.11.13 09:12:00.334996 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.348964 [ 10181 ] {a53c1854-d4f8-45a8-9c63-24819471ada7} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 516, line 517) (in query: SELECT enabledProfiles(NULL, NULL, NULL);) 2025.11.13 09:12:00.363039 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.380822 [ 10181 ] {11f22752-295f-4390-bd35-3e7785b4ccc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 517, line 518) (in query: SELECT enabledRoles(NULL, NULL, NULL);) 2025.11.13 09:12:00.390129 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.436879 [ 18771 ] {00fb8e63-7475-42ed-80cd-4bcbed1c1e5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 97, line 98) (in query: SELECT REGEXP_MATCHES(NULL, NULL, NULL);) 2025.11.13 09:12:00.443053 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.456210 [ 10181 ] {f580d0dc-cdcc-410e-9658-71cf1ac1cf31} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 518, line 519) (in query: SELECT encodeURLComponent(NULL, NULL, NULL);) 2025.11.13 09:12:00.460839 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.514579 [ 10181 ] {b05fc910-a6ac-4a97-ba14-27d8b82c2b6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 519, line 520) (in query: SELECT encodeURLFormComponent(NULL, NULL, NULL);) 2025.11.13 09:12:00.529463 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.541587 [ 18771 ] {3000156a-3dac-4dd1-9d2d-0b043401fa5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 99, line 100) (in query: SELECT RIPEMD160(NULL, NULL, NULL);) 2025.11.13 09:12:00.546674 [ 10181 ] {bbed9ec9-d055-4d78-94c2-e7306bee8020} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 520, line 521) (in query: SELECT encodeXMLComponent(NULL, NULL, NULL);) 2025.11.13 09:12:00.557433 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.588169 [ 18771 ] {390713de-6be9-4ac8-b0ac-5e9b4ca69bb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 100, line 101) (in query: SELECT SCHEMA(NULL, NULL, NULL);) 2025.11.13 09:12:00.594241 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.658292 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.736103 [ 18771 ] {443a10b2-1649-4cbc-9de9-a5b550e40915} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 102, line 103) (in query: SELECT SHA1(NULL, NULL, NULL);) 2025.11.13 09:12:00.748227 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.761052 [ 3519 ] {} test_15.partitioned_table (743d6066-7bda-470c-912a-eafda92280d9): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_15/03008_deduplication_insert_into_partitioned_table/replicas/r1), cannot update queue. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3792: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000038a674a5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:418: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c91f5f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 7. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:00.761052 [ 3509 ] {} test_1.t_mutations_nondeterministic (9b00b00f-a69b-477d-bb9f-bc76e79cef48): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1), cannot update queue. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3792: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000038a674a5 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:418: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_1, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c91f5f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 7. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:00.765865 [ 18771 ] {db5e2bb0-ed2e-4389-84bd-f8a51145507e} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 103, line 104) (in query: SELECT SHA224(NULL, NULL, NULL);) 2025.11.13 09:12:00.770856 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.785862 [ 10181 ] {36720e6a-a31e-4256-9af5-0ee4405effcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 522, line 523) (in query: SELECT endsWith(NULL, NULL, NULL);) 2025.11.13 09:12:00.794665 [ 18771 ] {0bda5ecd-e5be-4005-ab28-e59e55a70324} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 104, line 105) (in query: SELECT SHA256(NULL, NULL, NULL);) 2025.11.13 09:12:00.799351 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.806078 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.815088 [ 10181 ] {2104f0e8-3ad0-4e75-a1f0-c1a2e1851302} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 523, line 524) (in query: SELECT endsWithUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:00.827113 [ 18771 ] {bee7b4ee-8503-4aa7-a534-36c34b6357bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 105, line 106) (in query: SELECT SHA384(NULL, NULL, NULL);) 2025.11.13 09:12:00.832240 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.861157 [ 18771 ] {db77e68c-66cd-49eb-ad25-956c7a4348ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 106, line 107) (in query: SELECT SHA512(NULL, NULL, NULL);) 2025.11.13 09:12:00.865249 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.886508 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:00.889673 [ 18771 ] {80219e18-d0c1-4ac6-b488-dc929f9333be} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 107, line 108) (in query: SELECT SHA512_256(NULL, NULL, NULL);) 2025.11.13 09:12:00.893995 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.036458 [ 10211 ] {f096eba0-559a-413c-930f-9f40e49c962a} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_1/02842_mutations_replace/replicas/1/is_active. (KEEPER_EXCEPTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57264) (comment: 02842_mutations_replace_non_deterministic.sql) (query 26, line 72) (in query: ALTER TABLE t_mutations_nondeterministic UPDATE v = now() WHERE 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000f1265ec 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:599: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003d005500 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:580: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cffc3f1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:707: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000388df46c 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7972: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x0000000038b14802 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7945: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000038b8b11d 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:01.041474 [ 10211 ] {} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_1/02842_mutations_replace/replicas/1/is_active. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000f1265ec 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:599: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x000000003d005500 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:580: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003cffc3f1 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:707: DB::StorageReplicatedMergeTree::waitMutationToFinishOnReplicas(std::vector> const&, String const&) const @ 0x00000000388df46c 7. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7972: DB::StorageReplicatedMergeTree::waitMutation(String const&, unsigned long) const @ 0x0000000038b14802 8. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:7945: DB::StorageReplicatedMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000038b8b11d 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:01.051372 [ 3511 ] {} test_1.t_mutations_nondeterministic (9b00b00f-a69b-477d-bb9f-bc76e79cef48): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003d0a7a6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160d5e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1565: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003d16fe74 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1358: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff8840 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:301: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff78a0 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:375: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9ec7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:337: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9bca 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a2ef3f9 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3830: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000038a68019 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:423: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_2, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c91f9f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:01.051372 [ 3513 ] {} test_15.partitioned_table (743d6066-7bda-470c-912a-eafda92280d9): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003d0a7a6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160d5e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1565: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003d16fe74 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1358: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff8840 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:301: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff78a0 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:375: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9ec7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:337: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9bca 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a2ef3f9 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3830: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000038a68019 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:423: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_2, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c91f9f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:01.054276 [ 10181 ] {324fccf4-56f1-41e2-b5fc-16bfbdee0840} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 525, line 526) (in query: SELECT equals(NULL, NULL, NULL);) 2025.11.13 09:12:01.062741 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.083132 [ 10181 ] {a2a1b67b-e806-4fbf-997c-f58ff131d50e} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 526, line 527) (in query: SELECT erf(NULL, NULL, NULL);) 2025.11.13 09:12:01.184705 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.207147 [ 10181 ] {b707002d-00b3-4793-941e-9eb08653adf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 527, line 528) (in query: SELECT erfc(NULL, NULL, NULL);) 2025.11.13 09:12:01.221150 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.236705 [ 10181 ] {f82cf932-849c-4d56-bee8-2679619de637} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 528, line 529) (in query: SELECT errorCodeToName(NULL, NULL, NULL);) 2025.11.13 09:12:01.238235 [ 3498 ] {} test_1.t_mutations_nondeterministic (9b00b00f-a69b-477d-bb9f-bc76e79cef48): void DB::StorageReplicatedMergeTree::mergeSelectingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_1/02842_mutations_replace/mutations. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000f1265ec 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:378: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cffa029 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:337: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9bca 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a2ef3f9 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:653: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x000000003a2dda49 8. ./build_docker/./src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:74: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x000000003a5957e9 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:ne190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003a36ea8f 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x000000003a33548e 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4156: DB::StorageReplicatedMergeTree::mergeSelectingTask()::$_0::operator()() const @ 0x0000000038a73ef2 12. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4189: DB::StorageReplicatedMergeTree::mergeSelectingTask() @ 0x0000000038a6cb19 13. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:430: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_3, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c91fdf 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 15. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:01.250807 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.266557 [ 10181 ] {e736bb12-2e07-4b1f-95cf-d31319b5eb41} executeQuery: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 529, line 530) (in query: SELECT estimateCompressionRatio(NULL, NULL, NULL);) 2025.11.13 09:12:01.272958 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.280706 [ 3592 ] {} test_1.t_mutations_nondeterministic (9b00b00f-a69b-477d-bb9f-bc76e79cef48): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1), cannot finalize mutations. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:4230: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x0000000038a78544 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:437: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_4, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c9201f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 7. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 8. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:01.377531 [ 10181 ] {5ea007ad-738d-4a4c-92f0-5a9ca1a7d5cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 531, line 532) (in query: SELECT exp(NULL, NULL, NULL);) 2025.11.13 09:12:01.385785 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.507438 [ 10181 ] {95691e16-22e8-455d-9d29-6b9a53aeb74c} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 532, line 533) (in query: SELECT exp10(NULL, NULL, NULL);) 2025.11.13 09:12:01.512823 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.515674 [ 18771 ] {0510a74c-292e-4b01-8e17-0a79a933fd03} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 114, line 115) (in query: SELECT TO_BASE64(NULL, NULL, NULL);) 2025.11.13 09:12:01.520089 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.539804 [ 10181 ] {4d040a2b-8a72-48ea-a5db-121ab0bf0dd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 533, line 534) (in query: SELECT exp2(NULL, NULL, NULL);) 2025.11.13 09:12:01.545398 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.623791 [ 10181 ] {d77fe3a8-b18d-41e4-bc92-07a86e35ef0b} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 535, line 536) (in query: SELECT exponentialTimeDecayedAvg(NULL, NULL, NULL);) 2025.11.13 09:12:01.629982 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.657241 [ 10181 ] {0cc2e1a9-a0a7-47b7-a9ec-55e4f079ad9f} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 536, line 537) (in query: SELECT exponentialTimeDecayedCount(NULL, NULL, NULL);) 2025.11.13 09:12:01.661578 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.688772 [ 10181 ] {6175e1b9-a32a-4b9c-9585-d362b95c49a1} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 537, line 538) (in query: SELECT exponentialTimeDecayedMax(NULL, NULL, NULL);) 2025.11.13 09:12:01.696620 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.723628 [ 10181 ] {09b60f4d-7f6c-4585-8034-f05da1fc8411} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 538, line 539) (in query: SELECT exponentialTimeDecayedSum(NULL, NULL, NULL);) 2025.11.13 09:12:01.728434 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.755238 [ 10181 ] {257c1a15-d439-4b19-93f2-a2fe09825452} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 539, line 540) (in query: SELECT extract(NULL, NULL, NULL);) 2025.11.13 09:12:01.858539 [ 18771 ] {5cf1f1bc-5e90-4887-bec5-6a227a807a78} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 119, line 120) (in query: SELECT URLHierarchy(NULL, NULL, NULL);) 2025.11.13 09:12:01.863844 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.885966 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.901873 [ 18771 ] {f0da5f49-61c9-4935-94d3-3a7bd4e18926} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 120, line 121) (in query: SELECT URLPathHierarchy(NULL, NULL, NULL);) 2025.11.13 09:12:01.906790 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.918611 [ 10181 ] {c0a7ac51-a37f-4b00-b560-c194360914ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 540, line 541) (in query: SELECT extractAll(NULL, NULL, NULL);) 2025.11.13 09:12:01.923275 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.933828 [ 18771 ] {3c6ca37d-8f2c-4ff9-a242-0853705280b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 121, line 122) (in query: SELECT UTCTimestamp(NULL, NULL, NULL);) 2025.11.13 09:12:01.938185 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.948014 [ 10181 ] {e955ec52-fb0d-4ea6-a781-70261ffb805b} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 541, line 542) (in query: SELECT extractAllGroups(NULL, NULL, NULL);) 2025.11.13 09:12:01.952652 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:01.977029 [ 10181 ] {ded90d91-726f-448e-9922-8a533f0407a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 542, line 543) (in query: SELECT extractAllGroupsHorizontal(NULL, NULL, NULL);) 2025.11.13 09:12:01.981671 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:02.005835 [ 10181 ] {07ecf2cf-1eee-4add-8cae-37abeac0a837} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 543, line 544) (in query: SELECT extractAllGroupsVertical(NULL, NULL, NULL);) 2025.11.13 09:12:02.010847 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:02.024314 [ 18771 ] {f9f240c0-9f2e-4ea5-a551-e0d3e6908fc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 122, line 123) (in query: SELECT UTC_timestamp(NULL, NULL, NULL);) 2025.11.13 09:12:02.028938 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:02.077019 [ 10181 ] {deeff40d-d4af-483f-bb27-6175d042e8b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 544, line 545) (in query: SELECT extractGroups(NULL, NULL, NULL);) 2025.11.13 09:12:02.081529 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:02.324526 [ 10181 ] {c6d90ca4-e8ee-4b8a-b922-568938602fc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 547, line 548) (in query: SELECT extractTextFromHTML(NULL, NULL, NULL);) 2025.11.13 09:12:02.331275 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:02.451103 [ 10181 ] {4503ec36-81c5-4a80-9cbf-8bb9b05d5cee} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 548, line 549) (in query: SELECT extractURLParameter(NULL, NULL, NULL);) 2025.11.13 09:12:02.455771 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:02.482817 [ 10181 ] {fbbb1c74-b884-4afd-9863-8780d611f8ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 549, line 550) (in query: SELECT extractURLParameterNames(NULL, NULL, NULL);) 2025.11.13 09:12:02.487757 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:02.516543 [ 10181 ] {6d91fa58-6404-435f-b1b4-964d2323010a} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 550, line 551) (in query: SELECT extractURLParameters(NULL, NULL, NULL);) 2025.11.13 09:12:02.521203 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:02.549448 [ 10181 ] {61705a9d-f3a8-4e99-993f-74a489820212} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 551, line 552) (in query: SELECT factorial(NULL, NULL, NULL);) 2025.11.13 09:12:02.555522 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:02.607990 [ 16235 ] {16ed6d9b-4dbb-43ba-9404-5074b6248013} executeQuery: Code: 57. DB::Exception: Table test_j2o2im67.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53192) (comment: 03279_subcolumns_in_primary_key_select_final.gen.sql) (query 15, line 26) (in query: CREATE TABLE test (`value` UInt64, `a` Tuple(b Tuple(c UInt32, d String, e Array(UInt32))), `data` String) ENGINE = SummingMergeTree(value) ORDER BY (a.b.c, a.b.d) SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, vertical_merge_algorithm_min_columns_to_activate = 10, vertical_merge_algorithm_min_rows_to_activate = 10000000000, index_granularity = 1, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 531764379, compact_parts_max_granules_to_buffer = 26, compact_parts_merge_max_bytes_to_prefetch_part = 19270924, merge_max_block_size = 23674, old_parts_lifetime = 22., prefer_fetch_merged_part_size_threshold = 10737418240, min_merge_bytes_to_use_direct_io = 4116289305, index_granularity_bytes = 31162454, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 56726, primary_key_compress_block_size = 83772, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:02.613915 [ 16235 ] {} TCPHandler: Code: 57. DB::Exception: Table test_j2o2im67.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:02.729577 [ 3175 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1403: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000031b06d66 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1425: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000031b07f49 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:219: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031b2b7df 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:02.750584 [ 10181 ] {23b24a4c-70f1-4759-95f0-d0e93b70c285} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 554, line 555) (in query: SELECT file(NULL, NULL, NULL);) 2025.11.13 09:12:02.755761 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:02.989767 [ 10181 ] {9d6e6340-1369-4d14-8bc3-b4bc0bcc73c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 558, line 559) (in query: SELECT finalizeAggregation(NULL, NULL, NULL);) 2025.11.13 09:12:02.994914 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.016290 [ 10181 ] {0ae38627-b542-4bb3-94b6-12a782ce11f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 559, line 560) (in query: SELECT firstLine(NULL, NULL, NULL);) 2025.11.13 09:12:03.022118 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.030954 [ 18771 ] {ce19bd5b-2ce1-4d0b-a558-1d0e3a65b541} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 134, line 135) (in query: SELECT _CAST(NULL, NULL, NULL);) 2025.11.13 09:12:03.035424 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.047347 [ 10181 ] {771969c4-2e57-4967-bf76-3323c82a6f53} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 560, line 561) (in query: SELECT firstSignificantSubdomain(NULL, NULL, NULL);) 2025.11.13 09:12:03.055231 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.063849 [ 18771 ] {77fd72e8-c9ff-4417-ad4f-30224c5c75a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 135, line 136) (in query: SELECT __actionName(NULL, NULL, NULL);) 2025.11.13 09:12:03.068176 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.077170 [ 10181 ] {1c7028e9-337f-46c5-900a-cfa6b85a822d} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 561, line 562) (in query: SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.11.13 09:12:03.081658 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.092830 [ 18771 ] {0985bf70-86b4-4f0e-a4ce-4cc6a75575da} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 136, line 137) (in query: SELECT __bitBoolMaskAnd(NULL, NULL, NULL);) 2025.11.13 09:12:03.104548 [ 10181 ] {1d5596b3-2191-46ba-995f-ea643bc1f255} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 562, line 563) (in query: SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.11.13 09:12:03.109006 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.132540 [ 10181 ] {159e27ab-96dc-4676-9056-bd0f0c103769} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 563, line 564) (in query: SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.11.13 09:12:03.138041 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.148500 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.161147 [ 10181 ] {b488b2bc-5a9a-48a8-869a-b4a607b819a6} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 564, line 565) (in query: SELECT firstValueRespectNulls(NULL, NULL, NULL);) 2025.11.13 09:12:03.165356 [ 18771 ] {ab719f48-35c9-4d07-8d54-e450bb0bf846} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 137, line 138) (in query: SELECT __bitBoolMaskOr(NULL, NULL, NULL);) 2025.11.13 09:12:03.165665 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.244978 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.274673 [ 18771 ] {96f34633-7f16-437e-9f9f-474b9728c2b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 138, line 139) (in query: SELECT __bitSwapLastTwo(NULL, NULL, NULL);) 2025.11.13 09:12:03.280984 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.312333 [ 18771 ] {0d842a41-360d-4cf5-a6e8-a76217301e3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 139, line 140) (in query: SELECT __bitWrapperFunc(NULL, NULL, NULL);) 2025.11.13 09:12:03.327889 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.347751 [ 18771 ] {4664e83b-906d-495c-8180-6925027a1932} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 140, line 141) (in query: SELECT __getScalar(NULL, NULL, NULL);) 2025.11.13 09:12:03.351931 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.463376 [ 10181 ] {ae816644-43d9-4544-8f6f-e76806d9bc1d} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 566, line 567) (in query: SELECT first_value_respect_nulls(NULL, NULL, NULL);) 2025.11.13 09:12:03.468052 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.469235 [ 18771 ] {b82ab630-e334-414f-8d73-c5ebb54a084e} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 141, line 142) (in query: SELECT __scalarSubqueryResult(NULL, NULL, NULL);) 2025.11.13 09:12:03.473475 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.499993 [ 10181 ] {5a06f52a-22ea-4492-b160-1473b90a6c50} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 567, line 568) (in query: SELECT flameGraph(NULL, NULL, NULL);) 2025.11.13 09:12:03.505448 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:03.517003 [ 18771 ] {ada9a072-aea1-4059-8cf9-ebed01c0e63e} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 142, line 143) (in query: SELECT abs(NULL, NULL, NULL);) 2025.11.13 09:12:03.521446 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.547504 [ 10181 ] {0abec107-674b-4257-b0b0-9cd24831ad56} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 568, line 569) (in query: SELECT flatten(NULL, NULL, NULL);) 2025.11.13 09:12:03.551323 [ 18771 ] {ac7c172a-e7b5-4fa5-910b-c8975b86baa8} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 143, line 144) (in query: SELECT accurateCast(NULL, NULL, NULL);) 2025.11.13 09:12:03.551960 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.555970 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.577928 [ 10181 ] {6497b20a-d592-40ad-9cc6-37ead81cf891} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 569, line 570) (in query: SELECT flattenTuple(NULL, NULL, NULL);) 2025.11.13 09:12:03.582264 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.582823 [ 18771 ] {5ae3accf-89e3-4f7f-ad43-839790b86e26} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 144, line 145) (in query: SELECT accurateCastOrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:03.587439 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Nullable(Nothing): In scope SELECT accurateCastOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:03.616704 [ 18771 ] {23e21c3c-09ee-44de-a046-9cf78026e07d} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 145, line 146) (in query: SELECT accurateCastOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:03.621576 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.650540 [ 18771 ] {ced610ce-6213-4e25-807f-57e4a0af39a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 146, line 147) (in query: SELECT acos(NULL, NULL, NULL);) 2025.11.13 09:12:03.655150 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.736950 [ 18771 ] {d0e1d064-3a87-41b9-9e53-16681eac657f} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 147, line 148) (in query: SELECT acosh(NULL, NULL, NULL);) 2025.11.13 09:12:03.757510 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.844164 [ 18771 ] {c280ab92-f83d-417a-a8f9-72ba7b3c69fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 148, line 149) (in query: SELECT addDate(NULL, NULL, NULL);) 2025.11.13 09:12:03.859398 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:03.871307 [ 10181 ] {e538d811-7d92-4c2e-8b7d-95f974ae411b} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 574, line 575) (in query: SELECT formatQuery(NULL, NULL, NULL);) 2025.11.13 09:12:03.876283 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.066909 [ 10181 ] {efd81876-6edd-4e7c-a02a-4e3c842d764c} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 575, line 576) (in query: SELECT formatQueryOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:04.072026 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.102891 [ 10181 ] {849ba869-ef5f-4ac7-8be4-b30276052cca} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 576, line 577) (in query: SELECT formatQuerySingleLine(NULL, NULL, NULL);) 2025.11.13 09:12:04.108019 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.119269 [ 18771 ] {c68410e1-8c38-469e-862a-17fb42dbc137} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 151, line 152) (in query: SELECT addInterval(NULL, NULL, NULL);) 2025.11.13 09:12:04.132100 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.135487 [ 10181 ] {0af07fbb-4236-41d6-b056-d2a9d70c8f0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 577, line 578) (in query: SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:04.147222 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.165193 [ 10181 ] {2bbab09a-35e8-43a6-80e9-1cbf59b56e93} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 578, line 579) (in query: SELECT formatReadableDecimalSize(NULL, NULL, NULL);) 2025.11.13 09:12:04.169703 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.193464 [ 10181 ] {ddd778f7-fadb-45c8-b68a-0cb228262c75} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 579, line 580) (in query: SELECT formatReadableQuantity(NULL, NULL, NULL);) 2025.11.13 09:12:04.197949 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.224445 [ 10181 ] {543c8733-7170-4f5a-baeb-5fafce0c5bc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 580, line 581) (in query: SELECT formatReadableSize(NULL, NULL, NULL);) 2025.11.13 09:12:04.229696 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.328202 [ 10181 ] {f499afbd-be9b-404d-8452-ae73aca90b6a} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 582, line 583) (in query: SELECT formatRow(NULL, NULL, NULL);) 2025.11.13 09:12:04.372769 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:04.400295 [ 10181 ] {c4558c3a-7b20-4d9d-917f-6c7ded4d3d00} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 583, line 584) (in query: SELECT formatRowNoNewline(NULL, NULL, NULL);) 2025.11.13 09:12:04.405081 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:04.463194 [ 10181 ] {d8644762-c796-4ca5-beec-a7cc96796223} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 584, line 585) (in query: SELECT fragment(NULL, NULL, NULL);) 2025.11.13 09:12:04.467827 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.496964 [ 10181 ] {b6ec355b-2883-41b2-ad5f-24f7013ebc1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 585, line 586) (in query: SELECT fromDaysSinceYearZero(NULL, NULL, NULL);) 2025.11.13 09:12:04.510805 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.529973 [ 10181 ] {c29f5709-fb10-46e0-83ac-6e57741d5531} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 586, line 587) (in query: SELECT fromDaysSinceYearZero32(NULL, NULL, NULL);) 2025.11.13 09:12:04.534896 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.559516 [ 10181 ] {4bd516e1-bf09-46ee-88ff-6509bc8337f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 587, line 588) (in query: SELECT fromModifiedJulianDay(NULL, NULL, NULL);) 2025.11.13 09:12:04.567154 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.606310 [ 10181 ] {7fff5d9c-b827-4123-8755-cb9eced21b11} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 588, line 589) (in query: SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:04.620962 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.640992 [ 10181 ] {a31862d7-5662-4b66-b885-501b1bff2aa5} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 589, line 590) (in query: SELECT fromUTCTimestamp(NULL, NULL, NULL);) 2025.11.13 09:12:04.646463 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:04.896132 [ 18771 ] {0531e396-5e14-493b-b465-bf33c224a57e} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 159, line 160) (in query: SELECT addTupleOfIntervals(NULL, NULL, NULL);) 2025.11.13 09:12:04.898987 [ 6005 ] {} HTTPServerRequest: Got an HTTP request with no content length and no chunked/multipart encoding, it may be impossible to distinguish graceful EOF from abnormal connection loss 2025.11.13 09:12:04.905844 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.077606 [ 18771 ] {309448eb-402e-49ec-8393-ec9b57134522} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 162, line 163) (in query: SELECT addressToLine(NULL, NULL, NULL);) 2025.11.13 09:12:05.082318 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.113156 [ 18771 ] {804c3342-f60c-423c-8ecb-4cba6b1226bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 163, line 164) (in query: SELECT addressToLineWithInlines(NULL, NULL, NULL);) 2025.11.13 09:12:05.119732 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.157027 [ 18771 ] {a30baf89-2af9-4add-9424-6cd17fc21c3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 164, line 165) (in query: SELECT addressToSymbol(NULL, NULL, NULL);) 2025.11.13 09:12:05.161218 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.205487 [ 10181 ] {635075f8-04d2-4edb-b81f-d6748008e78c} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 596, line 597) (in query: SELECT from_utc_timestamp(NULL, NULL, NULL);) 2025.11.13 09:12:05.211186 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.232989 [ 10181 ] {63bf3a6b-01b7-405e-91a9-fd27c829c49a} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 597, line 598) (in query: SELECT fullHostName(NULL, NULL, NULL);) 2025.11.13 09:12:05.237358 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.258205 [ 10181 ] {4fa55ca8-f25e-40c6-99d4-75096a16f39b} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 598, line 599) (in query: SELECT fuzzBits(NULL, NULL, NULL);) 2025.11.13 09:12:05.262263 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.328824 [ 10181 ] {f1e75fa1-bd61-4106-b9aa-fd7c039c85cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 600, line 601) (in query: SELECT gcd(NULL, NULL, NULL);) 2025.11.13 09:12:05.334942 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.363425 [ 10181 ] {a375c3ba-9ae8-4fd5-b1b3-6b04bbd14929} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 601, line 602) (in query: SELECT generateRandomStructure(NULL, NULL, NULL);) 2025.11.13 09:12:05.370015 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.422913 [ 10181 ] {018f7788-1156-4fb8-84d2-11a0b9ab32b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 3, should be 1: In scope SELECT generateSerialID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 602, line 603) (in query: SELECT generateSerialID(NULL, NULL, NULL);) 2025.11.13 09:12:05.455479 [ 6005 ] {} DynamicQueryHandler: Code: 381. DB::Exception: The Transfer-Encoding is not chunked and there is no Content-Length header for POST request. (HTTP_LENGTH_REQUIRED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/HTTPHandler.cpp:748: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003acecf91 5. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 6. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 7. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 8. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 9. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 10. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:05.501980 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 3, should be 1: In scope SELECT generateSerialID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.527491 [ 10181 ] {52b216cf-ffaf-4af1-b695-6ad0f79b000b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 603, line 604) (in query: SELECT generateSnowflakeID(NULL, NULL, NULL);) 2025.11.13 09:12:05.532590 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.748033 [ 10181 ] {6c02ffa6-3bba-4e6b-83a0-c11fdcd6b1d3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 605, line 606) (in query: SELECT generateUUIDv4(NULL, NULL, NULL);) 2025.11.13 09:12:05.764001 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.779233 [ 10181 ] {21be3708-1186-4d95-b193-d094e8e1f9af} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 606, line 607) (in query: SELECT generateUUIDv7(NULL, NULL, NULL);) 2025.11.13 09:12:05.783588 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.812517 [ 10181 ] {faa20c4d-e8aa-482b-a6df-fc541a597467} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 607, line 608) (in query: SELECT geoDistance(NULL, NULL, NULL);) 2025.11.13 09:12:05.818376 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.888497 [ 10181 ] {1b6ca44e-3222-4685-b548-4cc9d0d095a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 609, line 610) (in query: SELECT geoToS2(NULL, NULL, NULL);) 2025.11.13 09:12:05.892892 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:05.915889 [ 10181 ] {a5152034-631c-4e9b-baf6-45bd6e36bfc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 610, line 611) (in query: SELECT geohashDecode(NULL, NULL, NULL);) 2025.11.13 09:12:05.921459 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.125704 [ 18771 ] {0a274fa5-85b9-44f6-be08-9dbd26b6dfc4} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 176, line 177) (in query: SELECT anyLastRespectNulls(NULL, NULL, NULL);) 2025.11.13 09:12:06.130438 [ 10181 ] {819f2839-e89a-4ca2-b413-75cd44bb0b2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 612, line 613) (in query: SELECT geohashesInBox(NULL, NULL, NULL);) 2025.11.13 09:12:06.130779 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.135928 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.161808 [ 10181 ] {fa58bfd3-9e3d-42a2-8c7a-fd7393e56599} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 613, line 614) (in query: SELECT getClientHTTPHeader(NULL, NULL, NULL);) 2025.11.13 09:12:06.161808 [ 18771 ] {3b82e22e-7fba-4083-bca4-a8a8890d97c0} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 177, line 178) (in query: SELECT anyLast_respect_nulls(NULL, NULL, NULL);) 2025.11.13 09:12:06.169946 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.178340 [ 10181 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.11.13 09:12:06.195549 [ 10181 ] {df9187fd-b025-4588-994a-f8472aeb350a} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 614, line 615) (in query: SELECT getMacro(NULL, NULL, NULL);) 2025.11.13 09:12:06.196403 [ 18771 ] {5a8d18f5-cecd-4ffb-91bb-5f69655a960a} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 178, line 179) (in query: SELECT anyRespectNulls(NULL, NULL, NULL);) 2025.11.13 09:12:06.201034 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.205731 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.225374 [ 10181 ] {a8fbb804-d4d1-4de6-9809-91039a612478} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 615, line 616) (in query: SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL);) 2025.11.13 09:12:06.229834 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.255138 [ 10181 ] {e948a45f-a353-4dd5-a46e-b957ed671fbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 616, line 617) (in query: SELECT getOSKernelVersion(NULL, NULL, NULL);) 2025.11.13 09:12:06.259818 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.281262 [ 18771 ] {c8b49136-c38c-456c-ae8f-61ac2ec80f66} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 179, line 180) (in query: SELECT anyValueRespectNulls(NULL, NULL, NULL);) 2025.11.13 09:12:06.283812 [ 10181 ] {cd7f8463-b7f0-4102-9f0c-3f3ea29ddd37} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 617, line 618) (in query: SELECT getServerPort(NULL, NULL, NULL);) 2025.11.13 09:12:06.285613 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.287897 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.313833 [ 18771 ] {9a32ffcb-10de-44b1-91fb-e94ab2c1f6b9} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 180, line 181) (in query: SELECT any_respect_nulls(NULL, NULL, NULL);) 2025.11.13 09:12:06.316141 [ 10181 ] {d0c0d958-53b1-4e74-84f4-054c3c6df14c} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 618, line 619) (in query: SELECT getSetting(NULL, NULL, NULL);) 2025.11.13 09:12:06.318735 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.321677 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.348686 [ 10181 ] {98ca332d-125d-4634-be09-90ed7c347748} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 619, line 620) (in query: SELECT getSettingOrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:06.354217 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.382770 [ 10181 ] {2960dbba-cb5d-48d1-9d1f-c80c9bf660fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 620, line 621) (in query: SELECT getSizeOfEnumType(NULL, NULL, NULL);) 2025.11.13 09:12:06.387276 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.395776 [ 18771 ] {df4e0d53-c05c-4501-9298-15f5bdb1c2e0} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 182, line 183) (in query: SELECT any_value_respect_nulls(NULL, NULL, NULL);) 2025.11.13 09:12:06.399993 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.424469 [ 18771 ] {f005ff9a-2a4c-445b-9129-301eae0446d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 183, line 184) (in query: SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL);) 2025.11.13 09:12:06.428779 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.497754 [ 10181 ] {72d2a0c6-29bf-42ed-8354-ab99b2255b6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 621, line 622) (in query: SELECT getSubcolumn(NULL, NULL, NULL);) 2025.11.13 09:12:06.502788 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.530248 [ 10181 ] {a953fd32-59cc-4d13-bf7c-88dbf9b70cc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 622, line 623) (in query: SELECT getTypeSerializationStreams(NULL, NULL, NULL);) 2025.11.13 09:12:06.535219 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.604531 [ 10181 ] {73c1242d-31e0-4723-b794-6d86dbad0571} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 623, line 624) (in query: SELECT globalIn(NULL, NULL, NULL);) 2025.11.13 09:12:06.609566 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.639840 [ 10181 ] {bf5e32b4-e57a-4738-8384-7929497fd16d} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 624, line 625) (in query: SELECT globalInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:06.644575 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.672347 [ 10181 ] {6152e456-43bc-4661-a564-4e1caf859014} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 625, line 626) (in query: SELECT globalNotIn(NULL, NULL, NULL);) 2025.11.13 09:12:06.677475 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.703135 [ 10181 ] {fc840fda-eca6-41b0-ad81-cb9d23ffa4d1} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 626, line 627) (in query: SELECT globalNotInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:06.707935 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.735835 [ 10181 ] {f9f657f7-3ff5-425f-b59e-d5c23dbcd147} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 627, line 628) (in query: SELECT globalNotNullIn(NULL, NULL, NULL);) 2025.11.13 09:12:06.740488 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.765782 [ 10181 ] {eae9ba70-a34c-4b56-933a-da908e900cb0} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 628, line 629) (in query: SELECT globalNotNullInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:06.771088 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.797960 [ 10181 ] {72e7f0fb-e01d-45ff-9963-e7cfd729c41b} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 629, line 630) (in query: SELECT globalNullIn(NULL, NULL, NULL);) 2025.11.13 09:12:06.809990 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.825172 [ 10181 ] {59b3c20a-1fc1-469a-b8eb-7c2c0930723b} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 630, line 631) (in query: SELECT globalNullInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:06.829306 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.851448 [ 10181 ] {e743f703-55d0-4e4b-b210-37569bac6e3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 631, line 632) (in query: SELECT globalVariable(NULL, NULL, NULL);) 2025.11.13 09:12:06.855543 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.879301 [ 10181 ] {fa1adef8-8247-408a-8178-06111761e93b} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 632, line 633) (in query: SELECT greatCircleAngle(NULL, NULL, NULL);) 2025.11.13 09:12:06.883413 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.912941 [ 10181 ] {e465411d-7726-432a-94bf-fe26a82c6892} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 633, line 634) (in query: SELECT greatCircleDistance(NULL, NULL, NULL);) 2025.11.13 09:12:06.921311 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.949115 [ 10181 ] {9c09b53f-50c0-4fc7-be55-856340dd5957} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 634, line 635) (in query: SELECT greater(NULL, NULL, NULL);) 2025.11.13 09:12:06.960842 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:06.981184 [ 10181 ] {d25b5c85-bdef-4f1b-9335-31d99aaf44c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 635, line 636) (in query: SELECT greaterOrEquals(NULL, NULL, NULL);) 2025.11.13 09:12:06.991093 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:07.024631 [ 10170 ] {2022e531-9f04-4f79-815a-afd0b0349f65} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53492) (comment: 02004_invalid_partition_mutation_stuck.sql) (query 3, line 4) (in query: CREATE TABLE rep_data (`p` Int, `t` DateTime, INDEX idx t TYPE minmax GRANULARITY 1) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/rep_data', '1') PARTITION BY p ORDER BY t SETTINGS number_of_free_entries_in_pool_to_execute_mutation = 0, index_granularity = 36468, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 335867033, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 13342366, merge_max_block_size = 14543, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 9776883080, vertical_merge_algorithm_min_rows_to_activate = 486070, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 244570874, index_granularity_bytes = 21683863, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 16513, primary_key_compress_block_size = 93958, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:07.030006 [ 10170 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:07.037886 [ 16323 ] {7af54bf1-ac1c-45db-bcb7-bb6bbd930197} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=845). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53268) (comment: 00909_ngram_distance.sql) (query 35, line 41) (in query: SELECT Title, round(1000 * distance) FROM test_distance ORDER BY ngramDistanceUTF8(Title, 'привет как дела') as distance, Title;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:07.046043 [ 16323 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=845). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:07.203290 [ 16132 ] {26d62a12-162f-4d0d-9c50-1f4e20f15cba} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53458) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 1, line 1) (in query: select * from format(TSV, 'x UInt32, y UInt32', '1\t2\n\n') settings input_format_tsv_skip_trailing_empty_lines=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b9e0ebd 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b426f82 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:12:07.206895 [ 16132 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b9e0ebd 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b426f82 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:12:07.511564 [ 16132 ] {d05c891b-7d83-4578-a6ce-d40b18249aff} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n1\t2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53458) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 3, line 3) (in query: select * from format(TSV, 'x UInt32, y UInt32', '1\t2\n\n1\t2\n') settings input_format_tsv_skip_trailing_empty_lines=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b9e0ebd 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b426f82 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:12:07.514889 [ 16132 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n1\t2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b9e0ebd 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b426f82 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:12:07.540163 [ 16192 ] {db01b2df-6ae2-4a30-8aac-7baf751156e0} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_5.test_constraints (4679eac4-f81a-42e1-99fe-e528fae72a40) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53442) (comment: 00953_constraints_operations.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:07.642605 [ 16192 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_5.test_constraints (4679eac4-f81a-42e1-99fe-e528fae72a40) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:07.734837 [ 18771 ] {1ccf2191-3b79-4013-a31c-b4f0e65030bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 200, line 201) (in query: SELECT arrayDistinct(NULL, NULL, NULL);) 2025.11.13 09:12:07.741198 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:07.789130 [ 18771 ] {e263a323-a154-4406-a52d-08a0719c4bb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 201, line 202) (in query: SELECT arrayDotProduct(NULL, NULL, NULL);) 2025.11.13 09:12:07.794406 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:07.823581 [ 18771 ] {dcc5f30c-d99a-4524-96d7-933e84687092} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 202, line 203) (in query: SELECT arrayElement(NULL, NULL, NULL);) 2025.11.13 09:12:07.829192 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:07.852632 [ 17383 ] {70492c16-86a4-4b3e-ba42-301af7aa41f4} executeQuery: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53424) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 5, line 9) (in query: SELECT ignore(toFixedString('Lambda as function parameter', 28), toNullable(28), ignore(8)), sum(marks) FROM system.parts WHERE database = currentDatabase() GROUP BY GROUPING SETS ((2)) FORMAT Null settings optimize_injective_functions_in_group_by=1, optimize_group_by_function_keys=1, group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003056088b 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000003056104b 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000030551fd6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:12:07.856208 [ 17383 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003056088b 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000003056104b 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000030551fd6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:12:07.857979 [ 18771 ] {a8174766-3154-41d6-aeff-4e67d03821ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 203, line 204) (in query: SELECT arrayElementOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:07.863039 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:07.892931 [ 18771 ] {8d52dcf4-8bf7-4459-8acc-ef2eb6904c84} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 204, line 205) (in query: SELECT arrayEnumerate(NULL, NULL, NULL);) 2025.11.13 09:12:07.898041 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:08.490910 [ 16132 ] {fa033761-95b0-426a-b686-9b6dd0ba0316} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53458) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 4, line 5) (in query: select * from format(CSV, 'x UInt32, y UInt32', '1,2\n\n') settings input_format_csv_skip_trailing_empty_lines=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b4ec2b8 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43287e 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:12:08.495449 [ 16132 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b4ec2b8 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43287e 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:12:08.590943 [ 16132 ] {ebd521b3-97af-4047-8ab8-e09d0c1ae02d} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n1,2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "1,2" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53458) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 6, line 7) (in query: select * from format(CSV, 'x UInt32, y UInt32', '1,2\n\n1,2\n') settings input_format_csv_skip_trailing_empty_lines=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b4ec2b8 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43287e 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:12:08.672381 [ 16132 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n1,2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "1,2" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b4ec2b8 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43287e 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:12:08.686253 [ 18771 ] {e29910c0-5067-45c0-b39b-38c4b21cad93} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 215, line 216) (in query: SELECT arrayFlatten(NULL, NULL, NULL);) 2025.11.13 09:12:08.691963 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:08.720826 [ 18771 ] {66c22500-004f-42c2-b4c4-03ec3e469d3f} executeQuery: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 216, line 217) (in query: SELECT arrayFold(NULL, NULL, NULL);) 2025.11.13 09:12:08.725770 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:08.796559 [ 10181 ] {61ea6229-162c-4f00-b2ca-24eeb44b412e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 655, line 656) (in query: SELECT h3CellAreaM2(NULL, NULL, NULL);) 2025.11.13 09:12:08.796602 [ 18771 ] {0a9565e0-0161-4747-8a79-21eae38003e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 218, line 219) (in query: SELECT arrayJaccardIndex(NULL, NULL, NULL);) 2025.11.13 09:12:08.804758 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:08.813549 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:08.828242 [ 18771 ] {0528049f-85ae-4492-8059-713fc444f954} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 219, line 220) (in query: SELECT arrayJoin(NULL, NULL, NULL);) 2025.11.13 09:12:08.888854 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:08.902996 [ 10181 ] {49a75a62-6f2c-46e8-acc3-d12833b2a005} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 656, line 657) (in query: SELECT h3CellAreaRads2(NULL, NULL, NULL);) 2025.11.13 09:12:08.921136 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:08.939313 [ 10181 ] {f6cfbba2-761d-4350-bb03-69e9aa2b36d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 657, line 658) (in query: SELECT h3Distance(NULL, NULL, NULL);) 2025.11.13 09:12:08.943926 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:08.972638 [ 10181 ] {b41f4fd7-1a0f-44ac-9896-9ff22810eada} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 658, line 659) (in query: SELECT h3EdgeAngle(NULL, NULL, NULL);) 2025.11.13 09:12:08.979746 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.051212 [ 10181 ] {db39d747-5769-4f9d-ac5c-ecaca45d6aa4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 659, line 660) (in query: SELECT h3EdgeLengthKm(NULL, NULL, NULL);) 2025.11.13 09:12:09.055994 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.096636 [ 10181 ] {4da32e5f-a19b-4f83-a9ab-d0a2b81a1992} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 660, line 661) (in query: SELECT h3EdgeLengthM(NULL, NULL, NULL);) 2025.11.13 09:12:09.102598 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.127618 [ 10181 ] {dcb3f69e-75a9-4c48-9197-cc03dedf7cda} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 661, line 662) (in query: SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL);) 2025.11.13 09:12:09.136422 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.154497 [ 10181 ] {3b66af5f-612b-43f5-96f9-84bb295bd852} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 662, line 663) (in query: SELECT h3ExactEdgeLengthM(NULL, NULL, NULL);) 2025.11.13 09:12:09.159650 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.183107 [ 10181 ] {b793add8-5645-4d8e-872a-d1f3e6843a0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 663, line 664) (in query: SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL);) 2025.11.13 09:12:09.187579 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.210555 [ 10181 ] {ad1e1297-d454-4b60-9227-f6bd8daae7ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 664, line 665) (in query: SELECT h3GetBaseCell(NULL, NULL, NULL);) 2025.11.13 09:12:09.216974 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.240595 [ 10181 ] {2ab46f6c-c0e7-4549-b4e7-95bd68d194ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 665, line 666) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.11.13 09:12:09.245103 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.289882 [ 10181 ] {94879eb1-4ed3-4f3f-bb60-5e33efda5eda} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 666, line 667) (in query: SELECT h3GetFaces(NULL, NULL, NULL);) 2025.11.13 09:12:09.294648 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.322821 [ 10181 ] {e5bdb836-6754-408a-a593-ea2813cf926a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 667, line 668) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.11.13 09:12:09.329158 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.355916 [ 10181 ] {0bac8424-4f06-464e-b7ac-4b30054dd70a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 668, line 669) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.11.13 09:12:09.360855 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.418534 [ 10181 ] {9d3fb515-b043-49c0-adb8-da6322db4995} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 669, line 670) (in query: SELECT h3GetPentagonIndexes(NULL, NULL, NULL);) 2025.11.13 09:12:09.423952 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.459593 [ 18771 ] {4e2de250-dd06-4411-98ee-abd5d268eca6} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 3, should be 2: In scope SELECT arrayNormalizedGini(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 226, line 227) (in query: SELECT arrayNormalizedGini(NULL, NULL, NULL);) 2025.11.13 09:12:09.465276 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 3, should be 2: In scope SELECT arrayNormalizedGini(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.470457 [ 10181 ] {699d1c7b-aba4-4c1b-9429-6b88685f133e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 670, line 671) (in query: SELECT h3GetRes0Indexes(NULL, NULL, NULL);) 2025.11.13 09:12:09.535218 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.559513 [ 10181 ] {fa82a186-2d5f-4215-a7aa-ab3fbe2ab2ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 671, line 672) (in query: SELECT h3GetResolution(NULL, NULL, NULL);) 2025.11.13 09:12:09.564632 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.589057 [ 10181 ] {cbda8701-f6fc-413d-8beb-6337da7c87a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 672, line 673) (in query: SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL);) 2025.11.13 09:12:09.593359 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.619967 [ 10181 ] {7b745f63-bfdb-4267-9435-231b948154fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 673, line 674) (in query: SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL);) 2025.11.13 09:12:09.624378 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.655249 [ 10181 ] {48afc888-517e-4340-ad7e-4e4382440bbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 674, line 675) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL);) 2025.11.13 09:12:09.661546 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.679546 [ 10170 ] {c55e7a91-4c8d-46ca-b059-bbb3ea34148a} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(nan, 3.14, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53538) (comment: 01854_s2_cap_contains.sql) (query 4, line 8) (in query: select s2CapContains(nan, 3.14, 1157339245694594829);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008c45817 4. DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a4314fa 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:09.683715 [ 10170 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(nan, 3.14, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008c45817 4. DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a4314fa 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:09.713113 [ 10181 ] {991a009a-c5ce-4b9c-9ad3-af7e6466d2f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 675, line 676) (in query: SELECT h3HexAreaKm2(NULL, NULL, NULL);) 2025.11.13 09:12:09.718928 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.748650 [ 10181 ] {339367a7-3b57-4f90-8fe7-8e32028cdbeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 676, line 677) (in query: SELECT h3HexAreaM2(NULL, NULL, NULL);) 2025.11.13 09:12:09.753513 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.780464 [ 10181 ] {b0c57707-841c-48a8-9aa5-56fe84ac3939} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 677, line 678) (in query: SELECT h3HexRing(NULL, NULL, NULL);) 2025.11.13 09:12:09.841886 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.867892 [ 10181 ] {84e2697d-48fa-4211-9a43-00797a6b2bd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 678, line 679) (in query: SELECT h3IndexesAreNeighbors(NULL, NULL, NULL);) 2025.11.13 09:12:09.876686 [ 16132 ] {300f7f48-0729-45df-a553-0fd70271be23} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53458) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 7, line 9) (in query: select * from format(CustomSeparated, 'x UInt32, y UInt32', '1\t2\n\n\n') settings input_format_custom_skip_trailing_empty_lines=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001f9723b0 5. ./src/IO/ReadHelpers.h:219: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b58caf1 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e622 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 18. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:12:09.880420 [ 16132 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001f9723b0 5. ./src/IO/ReadHelpers.h:219: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b58caf1 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e622 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 18. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:12:09.957142 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:09.972662 [ 16132 ] {1cf3ab3c-9bd8-4292-8d2c-4f897652c68a} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n1\t2\n\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53458) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 9, line 11) (in query: select * from format(CustomSeparated, 'x UInt32, y UInt32', '1\t2\n\n\n1\t2\n\n\n') settings input_format_custom_skip_trailing_empty_lines=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001f9723b0 5. ./src/IO/ReadHelpers.h:219: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b58caf1 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e622 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 18. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:12:09.973665 [ 10181 ] {0156977a-444b-40a6-ba41-2d691c1cd594} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 679, line 680) (in query: SELECT h3IsPentagon(NULL, NULL, NULL);) 2025.11.13 09:12:09.975822 [ 16132 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n1\t2\n\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001f9723b0 5. ./src/IO/ReadHelpers.h:219: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b58caf1 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e622 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 18. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:12:09.978601 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.005037 [ 10181 ] {7d549d37-feba-4bdc-91d6-76e321adaff4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 680, line 681) (in query: SELECT h3IsResClassIII(NULL, NULL, NULL);) 2025.11.13 09:12:10.009937 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.036006 [ 10181 ] {a8e46f6b-9027-4ff6-9ba0-60008630f0ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 681, line 682) (in query: SELECT h3IsValid(NULL, NULL, NULL);) 2025.11.13 09:12:10.041004 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.066762 [ 10181 ] {f9724278-dd85-41bd-856a-7189374f1b12} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 682, line 683) (in query: SELECT h3Line(NULL, NULL, NULL);) 2025.11.13 09:12:10.071385 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.085038 [ 18771 ] {99c7fcf6-97a9-42a0-91e8-dd2a60f4b231} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 231, line 232) (in query: SELECT arrayPopBack(NULL, NULL, NULL);) 2025.11.13 09:12:10.089704 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.098394 [ 10181 ] {ef24b53e-67eb-4f56-b054-0b31cc91c880} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 683, line 684) (in query: SELECT h3NumHexagons(NULL, NULL, NULL);) 2025.11.13 09:12:10.103012 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.124211 [ 18771 ] {75384ba1-5a63-4904-b1a1-72bb82d47c8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 232, line 233) (in query: SELECT arrayPopFront(NULL, NULL, NULL);) 2025.11.13 09:12:10.129947 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.130690 [ 10181 ] {503a248e-acac-487f-842d-f37bf387b94a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 684, line 685) (in query: SELECT h3PointDistKm(NULL, NULL, NULL);) 2025.11.13 09:12:10.136567 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.163060 [ 10181 ] {3c01ee1d-08be-4422-8ae7-d0b91e2a0410} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 685, line 686) (in query: SELECT h3PointDistM(NULL, NULL, NULL);) 2025.11.13 09:12:10.168903 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.197493 [ 10181 ] {2af760df-4cf0-47e3-90a6-f759eef1197a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 686, line 687) (in query: SELECT h3PointDistRads(NULL, NULL, NULL);) 2025.11.13 09:12:10.206004 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.210876 [ 18771 ] {f2b1ad12-3c4e-40d9-a105-28a60831156b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 234, line 235) (in query: SELECT arrayPushBack(NULL, NULL, NULL);) 2025.11.13 09:12:10.216757 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.222373 [ 17383 ] {b75392d1-0635-4096-a732-af007d98e5c7} executeQuery: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53424) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 15, line 49) (in query: SELECT count('Lambda as function parameter') AS c FROM (SELECT ignore(ignore('Lambda as function parameter', 28, 28, 28, 28, 28, 28), 28), materialize('Lambda as function parameter'), 28, 28, 'world', 5 FROM system.numbers WHERE ignore(materialize('Lambda as function parameter'), materialize(toLowCardinality(28)), 28, 28, 28, 28, toUInt128(28)) LIMIT 2) GROUP BY GROUPING SETS ((toLowCardinality(0)), (toLowCardinality(toNullable(28))), (1)) HAVING nullIf(c, 10) < 50 ORDER BY c ASC NULLS FIRST settings group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003056088b 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000003056104b 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000030551fd6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:12:10.226931 [ 17383 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003056088b 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000003056104b 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000030551fd6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:12:10.240885 [ 10181 ] {f43404e3-4751-44ac-817c-0a5286dcfa26} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 687, line 688) (in query: SELECT h3ToCenterChild(NULL, NULL, NULL);) 2025.11.13 09:12:10.246640 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.248002 [ 18771 ] {a787540f-a495-4bc0-baf1-448cec2fef50} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 235, line 236) (in query: SELECT arrayPushFront(NULL, NULL, NULL);) 2025.11.13 09:12:10.252629 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.296573 [ 10181 ] {35599a73-c1b4-4480-ada5-dcf1569e6484} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 688, line 689) (in query: SELECT h3ToChildren(NULL, NULL, NULL);) 2025.11.13 09:12:10.305179 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.335535 [ 10181 ] {09da8017-9f14-4077-bab4-65dcb8b22905} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 689, line 690) (in query: SELECT h3ToGeo(NULL, NULL, NULL);) 2025.11.13 09:12:10.339204 [ 18771 ] {59a08f11-2825-4157-ad14-455442cee2c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 237, line 238) (in query: SELECT arrayRandomSample(NULL, NULL, NULL);) 2025.11.13 09:12:10.346044 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.347603 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.374010 [ 18771 ] {14fbe9bf-33e8-4a18-9923-6798a5c01e9e} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 238, line 239) (in query: SELECT arrayReduce(NULL, NULL, NULL);) 2025.11.13 09:12:10.378843 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:10.429664 [ 10181 ] {cda77345-7952-4b23-8f09-75842b00f6f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 690, line 691) (in query: SELECT h3ToGeoBoundary(NULL, NULL, NULL);) 2025.11.13 09:12:10.434539 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.485465 [ 18771 ] {71971fc1-fe34-4fa2-ab05-701899ac77b2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayResize'. Expected: Array, got: Nullable(Nothing): In scope SELECT arrayResize(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 240, line 241) (in query: SELECT arrayResize(NULL, NULL, NULL);) 2025.11.13 09:12:10.490218 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array' to function 'arrayResize'. Expected: Array, got: Nullable(Nothing): In scope SELECT arrayResize(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:10.491112 [ 10181 ] {4e8597e5-a7b8-4cc5-86a5-b8adc0b8ff84} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 691, line 692) (in query: SELECT h3ToParent(NULL, NULL, NULL);) 2025.11.13 09:12:10.505822 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.519535 [ 10181 ] {9f0d892d-8c1e-42a9-b906-7f7363db75f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 692, line 693) (in query: SELECT h3ToString(NULL, NULL, NULL);) 2025.11.13 09:12:10.519535 [ 18771 ] {1da8b12b-beea-4dd6-8fe5-52e99d164616} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 241, line 242) (in query: SELECT arrayReverse(NULL, NULL, NULL);) 2025.11.13 09:12:10.525853 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.530747 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.551117 [ 10181 ] {153d8fc0-a681-4297-a886-d96922dfb3cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 693, line 694) (in query: SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL);) 2025.11.13 09:12:10.596789 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.618610 [ 10181 ] {8e888328-c7c8-4363-9314-e55919225315} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 694, line 695) (in query: SELECT h3kRing(NULL, NULL, NULL);) 2025.11.13 09:12:10.620097 [ 16054 ] {add49bd5-39e5-4a31-a0e6-fe904de59f63} executeQuery: Code: 36. DB::Exception: JOIN INNER JOIN ... USING (id, id, id) identifier 'id' appears more than once in USING clause. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53540) (comment: 02382_analyzer_matcher_join_using.sql) (query 18, line 40) (in query: SELECT * FROM test_table_join_1 AS t1 INNER JOIN test_table_join_2 AS t2 USING (id, id, id) ORDER BY id, t1.value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a2e342d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5192: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304c2fa9 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5381: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7826 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:10.622913 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.623442 [ 16054 ] {} TCPHandler: Code: 36. DB::Exception: JOIN INNER JOIN ... USING (id, id, id) identifier 'id' appears more than once in USING clause. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a2e342d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5192: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304c2fa9 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5381: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7826 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:10.699248 [ 10181 ] {66156a58-9283-48d2-a431-afbe71ec9e09} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 696, line 697) (in query: SELECT has(NULL, NULL, NULL);) 2025.11.13 09:12:10.705567 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.732463 [ 10181 ] {e2cacd8f-e260-4955-86b0-1012e60f763c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 697, line 698) (in query: SELECT hasAll(NULL, NULL, NULL);) 2025.11.13 09:12:10.738178 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.826500 [ 18771 ] {3477485c-9aa8-4a82-a653-51680e98c34b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 245, line 246) (in query: SELECT arrayRotateLeft(NULL, NULL, NULL);) 2025.11.13 09:12:10.826511 [ 10181 ] {a5aef5a5-dbd1-4883-a99f-14c99cea8688} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 698, line 699) (in query: SELECT hasAny(NULL, NULL, NULL);) 2025.11.13 09:12:10.831127 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.831127 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.858420 [ 18771 ] {11394931-ac14-4caa-a9c6-d618a1a612c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 246, line 247) (in query: SELECT arrayRotateRight(NULL, NULL, NULL);) 2025.11.13 09:12:10.863130 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.923030 [ 10181 ] {2a34b752-db0d-43cd-a8e0-fddcd39a5e8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 700, line 701) (in query: SELECT hasSubsequence(NULL, NULL, NULL);) 2025.11.13 09:12:10.927865 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:10.966559 [ 10181 ] {73f3e2a6-2a82-4dab-acf2-b93c126c30ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 701, line 702) (in query: SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:10.981800 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.011322 [ 10181 ] {111c45db-4911-4a05-9b2c-96faaa946b83} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 702, line 703) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:11.016220 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.050935 [ 10181 ] {b3128e29-01b8-4190-8e19-02c8a5a5db72} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 703, line 704) (in query: SELECT hasSubsequenceUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:11.052416 [ 18771 ] {b55bec45-6663-4822-a214-f07f2ec58d99} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 249, line 250) (in query: SELECT arrayShingles(NULL, NULL, NULL);) 2025.11.13 09:12:11.058305 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.059810 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.083623 [ 10181 ] {8a16c6a0-2e60-4356-87c5-b38a0a46b40f} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 704, line 705) (in query: SELECT hasSubstr(NULL, NULL, NULL);) 2025.11.13 09:12:11.088830 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.126156 [ 10181 ] {65b56e51-23b9-41ac-9e02-4b0ebe61976f} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 705, line 706) (in query: SELECT hasThreadFuzzer(NULL, NULL, NULL);) 2025.11.13 09:12:11.130915 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.157029 [ 10181 ] {406eb750-3c12-4bcc-9b07-81a63f59d01a} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 706, line 707) (in query: SELECT hasToken(NULL, NULL, NULL);) 2025.11.13 09:12:11.161821 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.239000 [ 10181 ] {b14c6d52-9b7c-4bb2-a034-49809d1f95dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 707, line 708) (in query: SELECT hasTokenCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:11.243771 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.270424 [ 10181 ] {0ea1e1ba-8735-430b-a7d7-d5cc05bc5e75} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 708, line 709) (in query: SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:11.275119 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.302364 [ 10181 ] {aecfe760-4dba-42b3-8668-b9c6cb032e10} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 709, line 710) (in query: SELECT hasTokenOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:11.307046 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.332403 [ 10181 ] {8f416194-dc75-4b3b-b375-f9586c3403e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 710, line 711) (in query: SELECT hex(NULL, NULL, NULL);) 2025.11.13 09:12:11.336635 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.363001 [ 10181 ] {72259896-940e-4623-bc8e-b471c8febf7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 711, line 712) (in query: SELECT hilbertDecode(NULL, NULL, NULL);) 2025.11.13 09:12:11.367557 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.610282 [ 10170 ] {56b7d7bc-0b9d-475e-87d9-bad155fcf487} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan in function s2CapContains: In scope SELECT s2CapContains(1157339245694594829, nan, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53538) (comment: 01854_s2_cap_contains.sql) (query 5, line 9) (in query: select s2CapContains(1157339245694594829, nan, 1157339245694594829);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a43024b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:12:11.613946 [ 10170 ] {} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan in function s2CapContains: In scope SELECT s2CapContains(1157339245694594829, nan, 1157339245694594829). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a43024b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:12:11.631032 [ 10170 ] {4b285868-d481-4440-8865-b72cbe4f8ed6} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(1157339245694594829, 3.14, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53538) (comment: 01854_s2_cap_contains.sql) (query 6, line 10) (in query: select s2CapContains(1157339245694594829, 3.14, nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008c45817 4. DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a4314fa 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:11.632646 [ 18771 ] {b78d38e2-a01f-4da3-83f9-1d7a9cb3b640} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 259, line 260) (in query: SELECT arrayWithConstant(NULL, NULL, NULL);) 2025.11.13 09:12:11.634115 [ 10170 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains(1157339245694594829, 3.14, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008c45817 4. DB::(anonymous namespace)::FunctionS2CapContains::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a4314fa 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:11.637907 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.738509 [ 10181 ] {660cac8f-4a04-4ffa-b666-ce4522d8a80b} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 718, line 719) (in query: SELECT hostName(NULL, NULL, NULL);) 2025.11.13 09:12:11.749891 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.766987 [ 10181 ] {aafbee6c-16eb-4a51-806a-72a9c941e2b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 719, line 720) (in query: SELECT hostname(NULL, NULL, NULL);) 2025.11.13 09:12:11.771622 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.794198 [ 10181 ] {eb102962-58fc-4994-8cb3-f5813a6a853a} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 720, line 721) (in query: SELECT hypot(NULL, NULL, NULL);) 2025.11.13 09:12:11.794198 [ 18771 ] {1884e042-8e95-4180-8e47-0c88562bceed} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 263, line 264) (in query: SELECT array_concat_agg(NULL, NULL, NULL);) 2025.11.13 09:12:11.801446 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function with Array suffix. Must be array. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:11.801446 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.821527 [ 10181 ] {acd958df-37d5-4202-9285-b16274d1f73e} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 3, should be 2: In scope SELECT icebergTruncate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 721, line 722) (in query: SELECT icebergTruncate(NULL, NULL, NULL);) 2025.11.13 09:12:11.828051 [ 18771 ] {adb6d2cd-aaf2-4a6f-b65a-7c10abea2d5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 264, line 265) (in query: SELECT ascii(NULL, NULL, NULL);) 2025.11.13 09:12:11.829762 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 3, should be 2: In scope SELECT icebergTruncate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.833735 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.851973 [ 10181 ] {8b538c2f-4a81-4f13-b835-dc74e8ea457f} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 722, line 723) (in query: SELECT identity(NULL, NULL, NULL);) 2025.11.13 09:12:11.857671 [ 18771 ] {5d3da85c-f93b-48cb-ac60-905f6969b6a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 265, line 266) (in query: SELECT asin(NULL, NULL, NULL);) 2025.11.13 09:12:11.858004 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.865800 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.885656 [ 18771 ] {974aa990-c116-432d-8ccb-3809d00a84f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 266, line 267) (in query: SELECT asinh(NULL, NULL, NULL);) 2025.11.13 09:12:11.890367 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.945664 [ 18771 ] {ed5c6d6b-388c-4a6f-92ac-8278b51298c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 267, line 268) (in query: SELECT assumeNotNull(NULL, NULL, NULL);) 2025.11.13 09:12:11.950315 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.960382 [ 10181 ] {f48274ec-19ac-49bc-876a-462a1d945215} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 723, line 724) (in query: SELECT idnaDecode(NULL, NULL, NULL);) 2025.11.13 09:12:11.964811 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.979855 [ 18771 ] {731f6c07-9a76-4244-9405-4226e789b51e} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 268, line 269) (in query: SELECT atan(NULL, NULL, NULL);) 2025.11.13 09:12:11.984368 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:11.987101 [ 10181 ] {9591f005-31d0-4685-a9e6-70336b686cf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 724, line 725) (in query: SELECT idnaEncode(NULL, NULL, NULL);) 2025.11.13 09:12:11.992785 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.061795 [ 18771 ] {aa945bc8-ed0f-42b7-a302-5470590ff0b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 269, line 270) (in query: SELECT atan2(NULL, NULL, NULL);) 2025.11.13 09:12:12.077775 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.097507 [ 18771 ] {6cdca9dd-db52-40c0-8951-6ffe3bb6a0d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 270, line 271) (in query: SELECT atanh(NULL, NULL, NULL);) 2025.11.13 09:12:12.103527 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.109804 [ 10181 ] {2ccc4f8f-a16e-4361-bd5b-de6c636c0361} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 726, line 727) (in query: SELECT ifNotFinite(NULL, NULL, NULL);) 2025.11.13 09:12:12.124711 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.130188 [ 18771 ] {4f3f7f7d-0744-4257-969c-6e5c0cd924a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 271, line 272) (in query: SELECT authUser(NULL, NULL, NULL);) 2025.11.13 09:12:12.137141 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.141922 [ 10181 ] {4f263e50-f0ac-4516-88c5-ff50191a112a} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 727, line 728) (in query: SELECT ifNull(NULL, NULL, NULL);) 2025.11.13 09:12:12.149759 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.163287 [ 18771 ] {5358ffd1-a76f-4275-885d-7a55ae7cc772} executeQuery: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authenticatedUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 272, line 273) (in query: SELECT authenticatedUser(NULL, NULL, NULL);) 2025.11.13 09:12:12.167756 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authenticatedUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.217449 [ 10181 ] {2d16316a-3452-4330-bbd4-8e8efbf2c016} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 729, line 730) (in query: SELECT ilike(NULL, NULL, NULL);) 2025.11.13 09:12:12.222571 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.245637 [ 10181 ] {58252c3c-da2c-4b71-8c4d-6f1b3eded38a} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 730, line 731) (in query: SELECT in(NULL, NULL, NULL);) 2025.11.13 09:12:12.251477 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.275778 [ 10181 ] {7632e501-c852-48bd-b18b-e80341697cc2} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 731, line 732) (in query: SELECT inIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:12.280398 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.361828 [ 18771 ] {50fe36c5-778d-4978-8708-3a6996424d61} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 276, line 277) (in query: SELECT base58Decode(NULL, NULL, NULL);) 2025.11.13 09:12:12.366469 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.397938 [ 18771 ] {89183111-d19f-4301-9bcb-10913ba5e8d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 277, line 278) (in query: SELECT base58Encode(NULL, NULL, NULL);) 2025.11.13 09:12:12.402968 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.475304 [ 18771 ] {7abfe2e1-5b1a-4b3b-94f6-bdafeef87cb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 278, line 279) (in query: SELECT base64Decode(NULL, NULL, NULL);) 2025.11.13 09:12:12.481044 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.515155 [ 18771 ] {d575d89e-bf2c-47b1-9d98-d6eedbef1cf3} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 279, line 280) (in query: SELECT base64Encode(NULL, NULL, NULL);) 2025.11.13 09:12:12.519796 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.523758 [ 10181 ] {93876456-b899-43ca-bafc-0d47facb0626} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 733, line 734) (in query: SELECT indexOf(NULL, NULL, NULL);) 2025.11.13 09:12:12.528824 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.546533 [ 18771 ] {d18f92e0-d2d5-4cae-8d97-87c0768b3425} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 280, line 281) (in query: SELECT base64URLDecode(NULL, NULL, NULL);) 2025.11.13 09:12:12.551166 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.625923 [ 10181 ] {2575cd56-a395-463b-b563-8b51f1dcbccb} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 734, line 735) (in query: SELECT indexOfAssumeSorted(NULL, NULL, NULL);) 2025.11.13 09:12:12.628252 [ 18771 ] {28dc4e60-9a69-472d-bd52-808614a679d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 281, line 282) (in query: SELECT base64URLEncode(NULL, NULL, NULL);) 2025.11.13 09:12:12.630974 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.632712 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.656515 [ 10181 ] {9cb0f274-54d5-4d36-b57a-c4603b192ed7} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 735, line 736) (in query: SELECT initcap(NULL, NULL, NULL);) 2025.11.13 09:12:12.659157 [ 18771 ] {854cb6b7-abca-48c5-83e2-bec8cbfac0de} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 282, line 283) (in query: SELECT basename(NULL, NULL, NULL);) 2025.11.13 09:12:12.663567 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.665526 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.689162 [ 18771 ] {a2a8e7c3-e1a3-4d1c-9b87-5b5f98bf4086} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 283, line 284) (in query: SELECT bin(NULL, NULL, NULL);) 2025.11.13 09:12:12.696761 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.763927 [ 10181 ] {5010a9f2-83ff-4b8d-8d79-cbe7a6652f2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 736, line 737) (in query: SELECT initcapUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:12.763961 [ 18771 ] {c6d57cbd-4832-4837-9380-f3b4404295ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 284, line 285) (in query: SELECT bitAnd(NULL, NULL, NULL);) 2025.11.13 09:12:12.768873 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.787927 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.794707 [ 10181 ] {ed4ef597-32f6-4ba4-b345-3f0c4c9b7889} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 737, line 738) (in query: SELECT initialQueryID(NULL, NULL, NULL);) 2025.11.13 09:12:12.799283 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.823421 [ 10181 ] {26496678-e0ba-4e81-aaec-e8f1ddeae0bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initialQueryStartTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 738, line 739) (in query: SELECT initialQueryStartTime(NULL, NULL, NULL);) 2025.11.13 09:12:12.827178 [ 18771 ] {c68f3d65-0f23-4524-bbcd-b0bf911c5386} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 285, line 286) (in query: SELECT bitCount(NULL, NULL, NULL);) 2025.11.13 09:12:12.828110 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initialQueryStartTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.832555 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.839279 [ 10170 ] {07617127-3d05-46a7-b6d0-f1b924e96975} executeQuery: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), -1., toUInt64(-1)). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53538) (comment: 01854_s2_cap_contains.sql) (query 7, line 13) (in query: select s2CapContains(toUInt64(-1), -1.0, toUInt64(-1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000ecb662d 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a430893 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:12:12.842720 [ 10170 ] {} TCPHandler: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), -1., toUInt64(-1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000ecb662d 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a430893 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:12:12.846448 [ 17383 ] {85ea18d7-6e44-46e4-83e9-0d184de493ad} executeQuery: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1': while executing 'FUNCTION arraySplit(number Array(Array(Nothing)) -> toUInt8(number) :: 1, array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String))) :: 2) -> arraySplit(number Array(Array(Nothing)) -> toUInt8(number), array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String)))) Array(Array(Array(Array(Nothing)))) : 4'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53424) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 19, line 57) (in query: SELECT count(arraySplit(number -> toUInt8(number), [arraySplit(x -> toUInt8(number), [])])) FROM numbers(10) GROUP BY number, [number] WITH ROLLUP settings group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c954489 5. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 12. ./src/Functions/FunctionsMiscellaneous.h:67: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000302b5be5 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 17. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x0000000037522ca0 18. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e75f8cb 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 2025.11.13 09:12:12.853467 [ 10181 ] {76f464a1-7780-4eda-83a5-c60c670d8c85} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 739, line 740) (in query: SELECT initial_query_id(NULL, NULL, NULL);) 2025.11.13 09:12:12.854943 [ 17383 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1': while executing 'FUNCTION arraySplit(number Array(Array(Nothing)) -> toUInt8(number) :: 1, array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String))) :: 2) -> arraySplit(number Array(Array(Nothing)) -> toUInt8(number), array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String)))) Array(Array(Array(Array(Nothing)))) : 4'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c954489 5. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 12. ./src/Functions/FunctionsMiscellaneous.h:67: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000302b5be5 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 17. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x0000000037522ca0 18. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e75f8cb 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:12.859633 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.861799 [ 18771 ] {89b10aee-e217-4463-bad5-47319835bf69} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 286, line 287) (in query: SELECT bitHammingDistance(NULL, NULL, NULL);) 2025.11.13 09:12:12.863210 [ 10170 ] {440c617a-f512-4613-941d-81bbd26fc624} executeQuery: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), 9999.9999, toUInt64(-1)). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53538) (comment: 01854_s2_cap_contains.sql) (query 8, line 14) (in query: select s2CapContains(toUInt64(-1), 9999.9999, toUInt64(-1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000ecb662d 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a430893 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:12:12.865993 [ 10170 ] {} TCPHandler: Code: 36. DB::Exception: Center (id 18446744073709551615) is not valid in function s2CapContains: In scope SELECT s2CapContains(toUInt64(-1), 9999.9999, toUInt64(-1)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000ecb662d 4. DB::(anonymous namespace)::FunctionS2CapContains::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a430893 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:12:12.867243 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.881360 [ 10181 ] {f2756226-7b47-4dee-b682-1e7aaa15a580} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initial_query_start_time(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 740, line 741) (in query: SELECT initial_query_start_time(NULL, NULL, NULL);) 2025.11.13 09:12:12.886392 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initial_query_start_time(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.890803 [ 18771 ] {1fd83f75-3825-4129-832c-e9b3dea240ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 287, line 288) (in query: SELECT bitNot(NULL, NULL, NULL);) 2025.11.13 09:12:12.895291 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:12.913775 [ 16230 ] {cf7248a4-5b04-4f2e-a1f8-94ffa7f4e4cf} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_5.test_constraints (4679eac4-f81a-42e1-99fe-e528fae72a40) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47114) (comment: 00953_constraints_operations.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:12.914645 [ 10181 ] {48a1e78c-3076-40b6-91fc-2e1951260f79} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 741, line 742) (in query: SELECT initializeAggregation(NULL, NULL, NULL);) 2025.11.13 09:12:12.920027 [ 16230 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_5.test_constraints (4679eac4-f81a-42e1-99fe-e528fae72a40) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:12.920518 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:12.992963 [ 18771 ] {5ec2c82a-64e4-4c5e-8aba-9b1389506932} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 288, line 289) (in query: SELECT bitOr(NULL, NULL, NULL);) 2025.11.13 09:12:13.032416 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.059422 [ 10181 ] {1f804b26-234e-46d0-a4a1-4a154654e371} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 743, line 744) (in query: SELECT intDiv(NULL, NULL, NULL);) 2025.11.13 09:12:13.059422 [ 18771 ] {145396be-fca1-416f-8d5a-78b1aff1a294} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 289, line 290) (in query: SELECT bitPositionsToArray(NULL, NULL, NULL);) 2025.11.13 09:12:13.063911 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.070894 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.090822 [ 10181 ] {8e91f982-d76e-40ba-91a8-68b33a5aab4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 744, line 745) (in query: SELECT intDivOrZero(NULL, NULL, NULL);) 2025.11.13 09:12:13.090822 [ 18771 ] {a8707230-e568-4f4e-b2a7-d377bd4d3921} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 290, line 291) (in query: SELECT bitRotateLeft(NULL, NULL, NULL);) 2025.11.13 09:12:13.096344 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.097249 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.123577 [ 18771 ] {78bf6824-9b41-4d0f-b84a-df67684a4c62} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 291, line 292) (in query: SELECT bitRotateRight(NULL, NULL, NULL);) 2025.11.13 09:12:13.128814 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.176528 [ 18771 ] {65bd4b14-90f9-4fd9-934a-9ddd9264623f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 292, line 293) (in query: SELECT bitShiftLeft(NULL, NULL, NULL);) 2025.11.13 09:12:13.183597 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.196795 [ 10181 ] {7f3a6d1d-47a6-48cd-a887-db50c7727986} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 745, line 746) (in query: SELECT intExp10(NULL, NULL, NULL);) 2025.11.13 09:12:13.201450 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.211330 [ 18771 ] {483bb12d-708a-4874-83f0-cd2ba290cf01} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 293, line 294) (in query: SELECT bitShiftRight(NULL, NULL, NULL);) 2025.11.13 09:12:13.216524 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.225646 [ 10181 ] {fc637bef-3d24-482c-95c6-a87099096de5} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 746, line 747) (in query: SELECT intExp2(NULL, NULL, NULL);) 2025.11.13 09:12:13.229961 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.253133 [ 10181 ] {73b6eec7-a318-4afd-810b-7d1137abf4ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 747, line 748) (in query: SELECT intHash32(NULL, NULL, NULL);) 2025.11.13 09:12:13.257478 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.282308 [ 10181 ] {c75b6d84-d602-4e7f-b5e9-16bc6ba09e06} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 748, line 749) (in query: SELECT intHash64(NULL, NULL, NULL);) 2025.11.13 09:12:13.288726 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.292979 [ 18771 ] {23c85b5d-8f1c-47b8-80c3-dd5b19923fac} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 295, line 296) (in query: SELECT bitTest(NULL, NULL, NULL);) 2025.11.13 09:12:13.339219 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.461194 [ 18771 ] {66ceb2f6-9678-45c8-ae08-088253a9180e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 298, line 299) (in query: SELECT bitXor(NULL, NULL, NULL);) 2025.11.13 09:12:13.461194 [ 10181 ] {44ec1262-3bb5-4e86-861a-02a06ec5d924} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 750, line 751) (in query: SELECT isConstant(NULL, NULL, NULL);) 2025.11.13 09:12:13.466281 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.466788 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.494870 [ 18771 ] {86904a28-92cf-429c-bcb5-4e3a53a55cd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 299, line 300) (in query: SELECT bitmapAnd(NULL, NULL, NULL);) 2025.11.13 09:12:13.500451 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.528525 [ 18771 ] {c6db7a29-ae89-436b-9026-210590d8d92b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 300, line 301) (in query: SELECT bitmapAndCardinality(NULL, NULL, NULL);) 2025.11.13 09:12:13.533444 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.533619 [ 10181 ] {6311e25b-733a-4b21-a647-ea5e3b184be0} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 752, line 753) (in query: SELECT isDynamicElementInSharedData(NULL, NULL, NULL);) 2025.11.13 09:12:13.537847 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.559258 [ 10181 ] {b1dad67b-cf82-4848-af5d-fed4204e05a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 753, line 754) (in query: SELECT isFinite(NULL, NULL, NULL);) 2025.11.13 09:12:13.559258 [ 18771 ] {37b76374-9479-4aee-80b2-c6fe7b951f03} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 301, line 302) (in query: SELECT bitmapAndnot(NULL, NULL, NULL);) 2025.11.13 09:12:13.563616 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.566948 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.589774 [ 10181 ] {f67c4d29-322e-4822-8388-02a57802cc28} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 754, line 755) (in query: SELECT isIPAddressInRange(NULL, NULL, NULL);) 2025.11.13 09:12:13.592823 [ 18771 ] {37895732-7c00-43a7-a740-1c4673756607} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 302, line 303) (in query: SELECT bitmapAndnotCardinality(NULL, NULL, NULL);) 2025.11.13 09:12:13.595300 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.602659 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.621325 [ 10181 ] {5d841d6a-1cee-4fe3-888c-5e7d67e156af} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 755, line 756) (in query: SELECT isIPv4String(NULL, NULL, NULL);) 2025.11.13 09:12:13.622858 [ 18771 ] {fab6bb1c-85b2-4186-a066-6cf783678904} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 303, line 304) (in query: SELECT bitmapBuild(NULL, NULL, NULL);) 2025.11.13 09:12:13.627254 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.651186 [ 10181 ] {2a4521f4-fb20-475b-837d-0dd8884bc761} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 756, line 757) (in query: SELECT isIPv6String(NULL, NULL, NULL);) 2025.11.13 09:12:13.654997 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.683667 [ 18771 ] {c222488a-4894-4bf8-a2be-14d86196c307} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 304, line 305) (in query: SELECT bitmapCardinality(NULL, NULL, NULL);) 2025.11.13 09:12:13.688444 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.714216 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.738811 [ 10181 ] {73eefc45-309e-4525-b70d-3b4496d94e10} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 757, line 758) (in query: SELECT isInfinite(NULL, NULL, NULL);) 2025.11.13 09:12:13.744543 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.754022 [ 16690 ] {4f9b7400-bd64-4cf4-a42e-021a1b1f2530} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47080) (comment: 00875_join_right_nulls_ors.sql) (query 12, line 17) (in query: SELECT 'n rj n', t1.x, t2.x FROM nt AS t1 RIGHT JOIN ntxy AS t2 ON t1.x = t2.x OR t1.x = t2.y ORDER BY t1.x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cecf2f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:13.760989 [ 16690 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cecf2f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:13.772305 [ 10181 ] {7b1d6dac-d327-43ab-a8eb-49d52864db97} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 758, line 759) (in query: SELECT isNaN(NULL, NULL, NULL);) 2025.11.13 09:12:13.777486 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.802170 [ 10181 ] {755b8d69-c0d9-4f48-a559-488156572471} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 759, line 760) (in query: SELECT isNotDistinctFrom(NULL, NULL, NULL);) 2025.11.13 09:12:13.812036 [ 18771 ] {00624e82-9d0f-4f62-bd22-23d66290a3e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 305, line 306) (in query: SELECT bitmapContains(NULL, NULL, NULL);) 2025.11.13 09:12:13.816787 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.842610 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.889062 [ 18771 ] {b8bbd5a3-86ae-43d7-acbb-09e5792a9ef6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 306, line 307) (in query: SELECT bitmapHasAll(NULL, NULL, NULL);) 2025.11.13 09:12:13.892126 [ 10181 ] {93330b81-6500-43cb-a22e-2dfd40b820cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 760, line 761) (in query: SELECT isNotNull(NULL, NULL, NULL);) 2025.11.13 09:12:13.895811 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.897502 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.923593 [ 10181 ] {f937bf62-cc24-4e52-9f4a-d682fb065fe1} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 761, line 762) (in query: SELECT isNull(NULL, NULL, NULL);) 2025.11.13 09:12:13.925921 [ 18771 ] {e70aea70-fcd7-4b5a-a7cb-8eca27feb178} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 307, line 308) (in query: SELECT bitmapHasAny(NULL, NULL, NULL);) 2025.11.13 09:12:13.930231 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.936615 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.955046 [ 10181 ] {75625a0c-35da-4927-bc08-ac96c35bd7c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 762, line 763) (in query: SELECT isNullable(NULL, NULL, NULL);) 2025.11.13 09:12:13.959633 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:13.980239 [ 10181 ] {36084501-20be-4aca-b005-f2c5034ae855} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 763, line 764) (in query: SELECT isValidJSON(NULL, NULL, NULL);) 2025.11.13 09:12:14.007963 [ 18771 ] {a6d200b0-3ad8-4005-9789-fff1ee11bfc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 308, line 309) (in query: SELECT bitmapMax(NULL, NULL, NULL);) 2025.11.13 09:12:14.012785 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.043911 [ 18771 ] {f9ca48a1-92a4-45cb-8256-37fbd12685ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 309, line 310) (in query: SELECT bitmapMin(NULL, NULL, NULL);) 2025.11.13 09:12:14.068297 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.087612 [ 10181 ] {228d809d-e513-43fc-8f22-4b4acac6ca31} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 764, line 765) (in query: SELECT isValidUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:14.093111 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.118534 [ 10181 ] {e89e64c7-0b99-4ba5-a9d7-3e7dc5968576} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 765, line 766) (in query: SELECT isZeroOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:14.118706 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.125545 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.147490 [ 18771 ] {c02ca55e-b7b9-473c-905f-0a46669922d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 310, line 311) (in query: SELECT bitmapOr(NULL, NULL, NULL);) 2025.11.13 09:12:14.152620 [ 10181 ] {5c17a25e-e6e6-4a02-9991-b840df2d42e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 766, line 767) (in query: SELECT jaroSimilarity(NULL, NULL, NULL);) 2025.11.13 09:12:14.159360 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.164718 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.184444 [ 18771 ] {2d16681b-e5e3-4ec1-bd66-979a6b17928c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 311, line 312) (in query: SELECT bitmapOrCardinality(NULL, NULL, NULL);) 2025.11.13 09:12:14.189354 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.227326 [ 10181 ] {82c5f37b-2df4-49df-9351-a035f3cb6d22} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 767, line 768) (in query: SELECT jaroWinklerSimilarity(NULL, NULL, NULL);) 2025.11.13 09:12:14.232007 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.309744 [ 18771 ] {e54a618a-ea22-4e79-93e4-269b320a28db} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 314, line 315) (in query: SELECT bitmapToArray(NULL, NULL, NULL);) 2025.11.13 09:12:14.317362 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.346264 [ 10181 ] {6cb7ec7d-4f1c-4b5c-8c74-a920ee7abc7c} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 770, line 771) (in query: SELECT joinGet(NULL, NULL, NULL);) 2025.11.13 09:12:14.351222 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:14.376292 [ 10181 ] {6ee110f8-1789-4c85-afcf-fa3049050770} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 771, line 772) (in query: SELECT joinGetOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:14.409834 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:14.493754 [ 18771 ] {bade1752-93ca-4178-9638-461b73a741f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 316, line 317) (in query: SELECT bitmapXor(NULL, NULL, NULL);) 2025.11.13 09:12:14.499408 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.529597 [ 18771 ] {637eec83-778a-4163-9cae-3a0ee2175762} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 317, line 318) (in query: SELECT bitmapXorCardinality(NULL, NULL, NULL);) 2025.11.13 09:12:14.534699 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.564317 [ 18771 ] {ddae1d01-3c73-402e-8c6e-ddd36310267a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 318, line 319) (in query: SELECT bitmaskToArray(NULL, NULL, NULL);) 2025.11.13 09:12:14.564317 [ 10181 ] {67a9d161-0f24-4f7f-ba7e-2ad1cb2c17de} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 773, line 774) (in query: SELECT jumpConsistentHash(NULL, NULL, NULL);) 2025.11.13 09:12:14.568611 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.568611 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.596014 [ 18771 ] {4168ec08-f534-4307-966f-cdd131b5ddb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 319, line 320) (in query: SELECT bitmaskToList(NULL, NULL, NULL);) 2025.11.13 09:12:14.639384 [ 10181 ] {82db2ef3-fdde-49a3-85ec-52a11fcfb4e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 3, should be 1: In scope SELECT keccak256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 775, line 776) (in query: SELECT keccak256(NULL, NULL, NULL);) 2025.11.13 09:12:14.644626 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 3, should be 1: In scope SELECT keccak256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.661979 [ 16690 ] {554ea5c9-29c9-488e-91d0-52e0a224aeea} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Values format file. Error: Code: 27. DB::Exception: Cannot parse input: expected ')' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47166) (comment: 02502_bad_values_schema_inference.sql) (query 1, line 1) (in query: desc format(Values, '(\'abc)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a3f964d 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ee8e9 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000026811c9c 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:14.665882 [ 16690 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Values format file. Error: Code: 27. DB::Exception: Cannot parse input: expected ')' at end of stream. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a3f964d 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ee8e9 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000026811c9c 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:14.701207 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.730473 [ 18771 ] {7d84f631-e3fb-470e-84e5-b95f18bbc973} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 320, line 321) (in query: SELECT blockNumber(NULL, NULL, NULL);) 2025.11.13 09:12:14.736036 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.789209 [ 10181 ] {95d1cb37-c0b0-4ea7-af4c-f5a363a23cff} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 777, line 778) (in query: SELECT kostikConsistentHash(NULL, NULL, NULL);) 2025.11.13 09:12:14.794598 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.874058 [ 18771 ] {0d9c6424-bf6f-467b-9739-c33cf84bc796} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 322, line 323) (in query: SELECT blockSize(NULL, NULL, NULL);) 2025.11.13 09:12:14.881942 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:14.996197 [ 18771 ] {69500d39-6336-443a-9dd8-52c48a782424} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 324, line 325) (in query: SELECT buildId(NULL, NULL, NULL);) 2025.11.13 09:12:15.003359 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.039667 [ 18771 ] {d887c162-d18f-4b63-8ac5-1e45e045e63c} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 325, line 326) (in query: SELECT byteHammingDistance(NULL, NULL, NULL);) 2025.11.13 09:12:15.063693 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.183109 [ 10181 ] {3b7157be-4609-4110-9f33-3e1fe20a9cc5} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 782, line 783) (in query: SELECT lagInFrame(NULL, NULL, NULL);) 2025.11.13 09:12:15.188952 [ 10181 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.11.13 09:12:15.226607 [ 18771 ] {c56f5355-62d5-4500-b733-4167d2c31279} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 328, line 329) (in query: SELECT byteSwap(NULL, NULL, NULL);) 2025.11.13 09:12:15.233884 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.322974 [ 10181 ] {5c3b8259-1897-4104-a162-fb82ac71b957} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 784, line 785) (in query: SELECT lastValueRespectNulls(NULL, NULL, NULL);) 2025.11.13 09:12:15.327320 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.481295 [ 18771 ] {8fb23ff8-0059-4691-bd6c-541ecdd6f45e} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 333, line 334) (in query: SELECT catboostEvaluate(NULL, NULL, NULL);) 2025.11.13 09:12:15.487612 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:15.497749 [ 10181 ] {85470586-080e-4c08-88ac-3da188078fe7} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 786, line 787) (in query: SELECT last_value_respect_nulls(NULL, NULL, NULL);) 2025.11.13 09:12:15.502301 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.515881 [ 18771 ] {8ead57e0-cab2-4a12-95b4-acd3c2668377} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 334, line 335) (in query: SELECT categoricalInformationValue(NULL, NULL, NULL);) 2025.11.13 09:12:15.520628 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:15.527864 [ 10181 ] {38ae35d4-e987-4c62-b91c-91a0bc9626cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 787, line 788) (in query: SELECT lcase(NULL, NULL, NULL);) 2025.11.13 09:12:15.545878 [ 18771 ] {aa73692d-090b-424e-b1a0-cdf162530b50} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 335, line 336) (in query: SELECT cbrt(NULL, NULL, NULL);) 2025.11.13 09:12:15.551588 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.620654 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.643128 [ 10181 ] {54a70571-b10c-4ace-ac7c-a3d111e28105} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 788, line 789) (in query: SELECT lcm(NULL, NULL, NULL);) 2025.11.13 09:12:15.647939 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.669328 [ 10181 ] {aa7f8801-9dc0-4c15-800e-6fdb9336b5af} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 789, line 790) (in query: SELECT leadInFrame(NULL, NULL, NULL);) 2025.11.13 09:12:15.676028 [ 10181 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.11.13 09:12:15.777355 [ 18771 ] {84cda012-6e53-49a3-8bee-56d96866a8f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 338, line 339) (in query: SELECT changeDay(NULL, NULL, NULL);) 2025.11.13 09:12:15.782006 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.871089 [ 18771 ] {8dc9a9c9-0730-4b0d-b418-047867e14d3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 339, line 340) (in query: SELECT changeHour(NULL, NULL, NULL);) 2025.11.13 09:12:15.878254 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.907740 [ 10181 ] {476989aa-705b-4f20-b31b-44f3b734180c} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 791, line 792) (in query: SELECT left(NULL, NULL, NULL);) 2025.11.13 09:12:15.914919 [ 18771 ] {36b71b02-b2e1-461a-b7b2-0154c2c1789f} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 340, line 341) (in query: SELECT changeMinute(NULL, NULL, NULL);) 2025.11.13 09:12:15.916831 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.932095 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.952502 [ 18771 ] {f1559dc3-a40b-4bab-a376-006242e68895} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 341, line 342) (in query: SELECT changeMonth(NULL, NULL, NULL);) 2025.11.13 09:12:15.959194 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:15.986565 [ 18771 ] {e5164a6c-23a1-45a5-a1e9-bec374e72260} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 342, line 343) (in query: SELECT changeSecond(NULL, NULL, NULL);) 2025.11.13 09:12:15.993809 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.020141 [ 18771 ] {af7ade13-83a4-426e-b649-dd98a35f6a42} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 343, line 344) (in query: SELECT changeYear(NULL, NULL, NULL);) 2025.11.13 09:12:16.026188 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.124159 [ 10181 ] {df7ea6b7-d1e3-4e70-94d3-f61d3f375d3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 794, line 795) (in query: SELECT leftUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:16.211918 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.231522 [ 10181 ] {cbe45759-0b17-47a1-b8d3-d5e55fc2535d} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 795, line 796) (in query: SELECT lemmatize(NULL, NULL, NULL);) 2025.11.13 09:12:16.243669 [ 10181 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:12:16.259118 [ 10181 ] {7387af5c-b098-482c-8a87-204fb82f8dc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 796, line 797) (in query: SELECT length(NULL, NULL, NULL);) 2025.11.13 09:12:16.271500 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.316678 [ 10181 ] {15cc4aa8-55a2-4835-b489-913bd86b867e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 797, line 798) (in query: SELECT lengthUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:16.327062 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.348101 [ 10181 ] {fe03dc02-c10a-45b8-900a-8f6afa0bb62b} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 798, line 799) (in query: SELECT less(NULL, NULL, NULL);) 2025.11.13 09:12:16.353697 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.375852 [ 10181 ] {1f692c5d-5ad4-44dd-825b-cca5d012256e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 799, line 800) (in query: SELECT lessOrEquals(NULL, NULL, NULL);) 2025.11.13 09:12:16.383699 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.404226 [ 10181 ] {2becc884-83c9-4e80-92d8-cf21151ebe87} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 800, line 801) (in query: SELECT levenshteinDistance(NULL, NULL, NULL);) 2025.11.13 09:12:16.409500 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.433292 [ 10181 ] {89dfe10a-7754-4e6a-8e64-ce29260e894a} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 801, line 802) (in query: SELECT levenshteinDistanceUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:16.443721 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.474963 [ 10181 ] {2ff0286e-693e-4b64-b082-52b5780f193f} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 802, line 803) (in query: SELECT lgamma(NULL, NULL, NULL);) 2025.11.13 09:12:16.482849 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.503253 [ 10181 ] {13fe5d17-554b-428b-b0a5-7669ead96f29} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 803, line 804) (in query: SELECT like(NULL, NULL, NULL);) 2025.11.13 09:12:16.509792 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.528685 [ 10181 ] {d9f52fcd-ec2b-4353-8a97-741619eba432} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 804, line 805) (in query: SELECT ln(NULL, NULL, NULL);) 2025.11.13 09:12:16.534766 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.600646 [ 10181 ] {6a8bc914-7690-4cdf-99cd-2aebf450520a} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 806, line 807) (in query: SELECT log(NULL, NULL, NULL);) 2025.11.13 09:12:16.608044 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.631687 [ 10181 ] {ca7dee2f-4c0e-43fd-a496-d87b915d881f} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 807, line 808) (in query: SELECT log10(NULL, NULL, NULL);) 2025.11.13 09:12:16.637728 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.739910 [ 18771 ] {4c839cdf-7a00-4e61-8056-a88bcb7b9239} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 354, line 355) (in query: SELECT connectionId(NULL, NULL, NULL);) 2025.11.13 09:12:16.748294 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.750875 [ 10181 ] {28340089-a870-4751-a3aa-42059b79b833} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 808, line 809) (in query: SELECT log1p(NULL, NULL, NULL);) 2025.11.13 09:12:16.763450 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.776091 [ 18771 ] {90b47bbe-3ad3-4a2d-9073-85fedd8f333f} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 355, line 356) (in query: SELECT connection_id(NULL, NULL, NULL);) 2025.11.13 09:12:16.778937 [ 10181 ] {73b68bfe-4d3d-47ce-9afe-3069b0f675e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 809, line 810) (in query: SELECT log2(NULL, NULL, NULL);) 2025.11.13 09:12:16.787061 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.805655 [ 10181 ] {2a7015d2-591e-4d80-9101-e0fc4ac15e73} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 810, line 811) (in query: SELECT logTrace(NULL, NULL, NULL);) 2025.11.13 09:12:16.810188 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.831995 [ 10181 ] {a768be82-5eb0-4522-9f99-6284846fd019} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 811, line 812) (in query: SELECT lowCardinalityIndices(NULL, NULL, NULL);) 2025.11.13 09:12:16.836744 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.858847 [ 10181 ] {df5b5960-1432-41b4-869f-efffc16a9b9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 812, line 813) (in query: SELECT lowCardinalityKeys(NULL, NULL, NULL);) 2025.11.13 09:12:16.864430 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.887158 [ 10181 ] {69419b34-3497-42c7-81ed-b8ef253522a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 813, line 814) (in query: SELECT lower(NULL, NULL, NULL);) 2025.11.13 09:12:16.892269 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.916276 [ 10181 ] {610eea98-99d3-4e7a-a1cf-ab473f11d5a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 814, line 815) (in query: SELECT lowerUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:16.921282 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:16.944697 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:17.180334 [ 17268 ] {cdf53ba0-8f0d-4d01-854c-4a225fd2e707} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=6): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47256) (comment: 03221_mutation_analyzer_skip_part.sh) (query 1, line 1) (in query: SELECT count() FROM system.part_log WHERE database = currentDatabase() AND table = 't_mutate_skip_part' AND event_type = 'MutatePart'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13d1f 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:277: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b5e2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:161: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3e28b7 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c2eb3f4 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 18. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:12:17.194363 [ 17268 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=6): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13d1f 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:277: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b5e2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:161: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3e28b7 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c2eb3f4 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 18. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:17.325690 [ 18771 ] {1cb8d01d-dd90-4562-9eb5-9bc093bce35e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 361, line 362) (in query: SELECT cos(NULL, NULL, NULL);) 2025.11.13 09:12:17.333561 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:17.385122 [ 18771 ] {e5db2617-6815-4e62-92ff-8aeac068740f} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 362, line 363) (in query: SELECT cosh(NULL, NULL, NULL);) 2025.11.13 09:12:17.392046 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:17.392306 [ 16194 ] {c57abf07-45cb-417a-af61-b8dcc6c0f077} executeQuery: Code: 215. DB::Exception: Column key_a is not under aggregate function and not in GROUP BY keys. In query SELECT key_a + key_b AS d, rank() OVER (PARTITION BY key_a + key_b) AS f FROM (SELECT rand() % 10 AS key_a, rand(1) % 5 AS key_b, number FROM numbers(100)) GROUP BY key_a, key_b WITH ROLLUP ORDER BY multiIf(d = 0, key_a, NULL) ASC. (NOT_AN_AGGREGATE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47272) (comment: 03146_tpc_ds_grouping.sql) (query 3, line 21) (in query: SELECT key_a + key_b AS d, rank() OVER (PARTITION BY key_a + key_b) AS f FROM ( SELECT rand() % 10 AS key_a, rand(1) % 5 AS key_b, number FROM numbers(100) ) GROUP BY key_a, key_b WITH ROLLUP ORDER BY multiIf(d = 0, key_a, NULL) ASC FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030557281 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 9. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 11. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003055485d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:17.401338 [ 16194 ] {} TCPHandler: Code: 215. DB::Exception: Column key_a is not under aggregate function and not in GROUP BY keys. In query SELECT key_a + key_b AS d, rank() OVER (PARTITION BY key_a + key_b) AS f FROM (SELECT rand() % 10 AS key_a, rand(1) % 5 AS key_b, number FROM numbers(100)) GROUP BY key_a, key_b WITH ROLLUP ORDER BY multiIf(d = 0, key_a, NULL) ASC. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030557281 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 9. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 11. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003055485d 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:17.418257 [ 18771 ] {9decf706-8f36-42b2-bfd5-093ab65af4b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 363, line 364) (in query: SELECT cosineDistance(NULL, NULL, NULL);) 2025.11.13 09:12:17.425539 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:17.448110 [ 18771 ] {c7f3d5f2-a34f-4769-bcc0-ca3e945ce804} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 364, line 365) (in query: SELECT count(NULL, NULL, NULL);) 2025.11.13 09:12:17.454638 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:17.508493 [ 18771 ] {6cb0dcc0-9119-48d3-8d6e-d0febb1ead1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 365, line 366) (in query: SELECT countDigits(NULL, NULL, NULL);) 2025.11.13 09:12:17.514052 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:17.541672 [ 18771 ] {1e137c52-5587-435e-917b-ea0d920f0e21} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 366, line 367) (in query: SELECT countEqual(NULL, NULL, NULL);) 2025.11.13 09:12:17.556874 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:17.581520 [ 18771 ] {a61efdb7-4d27-4b00-b13e-55308673f3a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 367, line 368) (in query: SELECT countMatches(NULL, NULL, NULL);) 2025.11.13 09:12:17.586107 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:17.608173 [ 10181 ] {698f43fe-eba6-4625-8534-cd8c0af6798e} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 822, line 824) (in query: SELECT map(NULL, NULL, NULL);) 2025.11.13 09:12:17.608804 [ 18771 ] {30327cd4-b21a-40cc-ac65-328d799d34c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 368, line 369) (in query: SELECT countMatchesCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:17.614276 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:17.615751 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:17.832432 [ 10181 ] {49b3ad7c-5048-4436-87e3-07485da4643a} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 827, line 829) (in query: SELECT mapContains(NULL, NULL, NULL);) 2025.11.13 09:12:17.836691 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.213728 [ 10181 ] {0af65cf3-af1d-484d-a035-9c2aafd93473} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 832, line 834) (in query: SELECT mapFromArrays(NULL, NULL, NULL);) 2025.11.13 09:12:18.228288 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.313309 [ 18771 ] {94048d10-81ab-4e05-865c-e0ce3766f545} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 380, line 381) (in query: SELECT curdate(NULL, NULL, NULL);) 2025.11.13 09:12:18.318719 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.337464 [ 10181 ] {d86710cf-033a-4ec1-abe8-a7a6dad80f5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 834, line 836) (in query: SELECT mapKeys(NULL, NULL, NULL);) 2025.11.13 09:12:18.346249 [ 18771 ] {079c0afb-4e84-4717-a0e3-b0ef2e01524e} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 381, line 382) (in query: SELECT currentDatabase(NULL, NULL, NULL);) 2025.11.13 09:12:18.350300 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.350667 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.378197 [ 18771 ] {4aeab9a0-c83b-4ea0-b99d-9510ac5c2bef} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 382, line 383) (in query: SELECT currentProfiles(NULL, NULL, NULL);) 2025.11.13 09:12:18.383325 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.419669 [ 18771 ] {54c4a204-cd46-4bee-8bf8-946330b78b70} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT currentQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 383, line 384) (in query: SELECT currentQueryID(NULL, NULL, NULL);) 2025.11.13 09:12:18.425209 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT currentQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.449819 [ 18771 ] {10ab1926-bd78-40ce-8d2d-6096d4c797a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 384, line 385) (in query: SELECT currentRoles(NULL, NULL, NULL);) 2025.11.13 09:12:18.462364 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.480270 [ 18771 ] {f2faeea4-5efd-4e34-85b4-1aa70f7ba28e} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 385, line 386) (in query: SELECT currentSchemas(NULL, NULL, NULL);) 2025.11.13 09:12:18.486113 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.516051 [ 18771 ] {d7369429-a324-471a-97de-4ecdcae37f37} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 386, line 387) (in query: SELECT currentUser(NULL, NULL, NULL);) 2025.11.13 09:12:18.521338 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.545494 [ 18771 ] {2bfbf5e4-f975-4fd4-93d7-4958511fe7bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 387, line 388) (in query: SELECT current_database(NULL, NULL, NULL);) 2025.11.13 09:12:18.550012 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.573639 [ 18771 ] {65e48496-735f-43a1-9ac7-314643364f8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 388, line 389) (in query: SELECT current_date(NULL, NULL, NULL);) 2025.11.13 09:12:18.580117 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.618409 [ 18771 ] {aec3ba6f-132f-435a-83ec-70d893d43267} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT current_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 389, line 390) (in query: SELECT current_query_id(NULL, NULL, NULL);) 2025.11.13 09:12:18.627208 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT current_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.645239 [ 18771 ] {72a607ac-0755-4cd7-bb31-83da194051f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 390, line 391) (in query: SELECT current_schemas(NULL, NULL, NULL);) 2025.11.13 09:12:18.653741 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.688344 [ 10181 ] {72a36d58-f242-48a0-ad92-d0f3bbd0f61c} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 841, line 843) (in query: SELECT mapUpdate(NULL, NULL, NULL);) 2025.11.13 09:12:18.693151 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.741120 [ 18771 ] {b4aa95de-ed6d-4de5-9809-c72524658ceb} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 391, line 392) (in query: SELECT current_timestamp(NULL, NULL, NULL);) 2025.11.13 09:12:18.748587 [ 10181 ] {09b2d098-b0f6-4cc1-83ee-be9f3d386a3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 842, line 844) (in query: SELECT mapValues(NULL, NULL, NULL);) 2025.11.13 09:12:18.756877 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.757921 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.777984 [ 10181 ] {caba63c9-0b60-4569-93ff-df0151153c8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 843, line 845) (in query: SELECT match(NULL, NULL, NULL);) 2025.11.13 09:12:18.782720 [ 18771 ] {80a04310-a844-4e3c-9d42-bb2eb339ba2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 392, line 393) (in query: SELECT current_user(NULL, NULL, NULL);) 2025.11.13 09:12:18.783062 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.797134 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.807905 [ 10181 ] {5884c972-f686-4c99-812d-7f03569703d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 844, line 846) (in query: SELECT materialize(NULL, NULL, NULL);) 2025.11.13 09:12:18.812730 [ 18771 ] {ce336e57-f822-4521-9d8c-b8e26ef6c7d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 393, line 394) (in query: SELECT cutFragment(NULL, NULL, NULL);) 2025.11.13 09:12:18.814482 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.822018 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.890251 [ 10181 ] {2b5f3fe1-5d9a-4518-a68b-29cb84188098} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 846, line 848) (in query: SELECT max2(NULL, NULL, NULL);) 2025.11.13 09:12:18.896626 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.915939 [ 18771 ] {a9bc9154-1d5b-4bf6-8df1-f966d959f20d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 395, line 396) (in query: SELECT cutQueryString(NULL, NULL, NULL);) 2025.11.13 09:12:18.920891 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:18.945652 [ 18771 ] {b38620e3-8f3c-4091-ab0d-1dd74a46f231} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 396, line 397) (in query: SELECT cutQueryStringAndFragment(NULL, NULL, NULL);) 2025.11.13 09:12:18.952472 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.043019 [ 18771 ] {c03894e2-4cf9-4674-b404-fc36228bca41} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 397, line 398) (in query: SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL);) 2025.11.13 09:12:19.049202 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.075354 [ 18771 ] {d7b1a81a-d365-40cb-acf0-2eb19b7dac12} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 398, line 399) (in query: SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.11.13 09:12:19.080941 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.114110 [ 18771 ] {dcbf0602-6f60-466f-b80e-eb40552d33df} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 399, line 400) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.11.13 09:12:19.122147 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.146560 [ 18771 ] {7395fd85-651d-477b-bf33-61a6803ea220} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 400, line 401) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL);) 2025.11.13 09:12:19.151648 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.179633 [ 18771 ] {4a9654be-9a19-437f-bea3-e9205d55e020} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 401, line 402) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL);) 2025.11.13 09:12:19.232760 [ 17268 ] {edbfcbf8-2a27-4de7-99a4-6b45aa94f029} executeQuery: Code: 44. DB::Exception: Sorting key cannot contain constants. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47314) (comment: 02679_query_parameters_dangling_pointer.sql) (query 2, line 4) (in query: CREATE TABLE test.xxx (`a` Int64) ENGINE = MergeTree ORDER BY 'a' SETTINGS index_granularity = 6666, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.986967146396637, replace_long_file_name_to_hash = true, max_file_name_length = 60, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 167391153, compact_parts_max_granules_to_buffer = 4, compact_parts_merge_max_bytes_to_prefetch_part = 1467890, merge_max_block_size = 15269, old_parts_lifetime = 258., prefer_fetch_merged_part_size_threshold = 4778687685, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 8577327736, index_granularity_bytes = 12663870, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 20, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 41189, primary_key_compress_block_size = 31069, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:676: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000003987b6c4 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:859: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000398781a3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003985f7e7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003985c161 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a49609f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a495477 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a487422 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:12:19.256307 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.289792 [ 17268 ] {} TCPHandler: Code: 44. DB::Exception: Sorting key cannot contain constants. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:676: DB::checkKeyExpression(DB::ExpressionActions const&, DB::Block const&, String const&, bool) @ 0x000000003987b6c4 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:859: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000398781a3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003985f7e7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003985c161 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a49609f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a495477 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a487422 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:12:19.296152 [ 18771 ] {651834ec-efb2-4490-8e12-5e16dbbaa7d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 402, line 403) (in query: SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.11.13 09:12:19.306257 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.330530 [ 18771 ] {68e1a79a-0e0c-43fe-8dc1-578515024121} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 403, line 404) (in query: SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL);) 2025.11.13 09:12:19.335495 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.363196 [ 18771 ] {e65c31d0-1049-40d9-893b-324a1740cfcf} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 404, line 405) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL);) 2025.11.13 09:12:19.367761 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.397036 [ 18771 ] {536644e1-b77a-4694-8805-e384aa216cf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 405, line 406) (in query: SELECT cutURLParameter(NULL, NULL, NULL);) 2025.11.13 09:12:19.401970 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.428186 [ 18771 ] {a3e53cb8-c3d8-4105-93a8-72203964b64a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 406, line 407) (in query: SELECT cutWWW(NULL, NULL, NULL);) 2025.11.13 09:12:19.433137 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.460456 [ 18771 ] {04c58162-1b5c-459a-adec-be6422cf22dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 407, line 408) (in query: SELECT damerauLevenshteinDistance(NULL, NULL, NULL);) 2025.11.13 09:12:19.465804 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.587777 [ 18771 ] {15d983bc-3886-4594-95b5-015d323915e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 410, line 411) (in query: SELECT dateTime64ToSnowflake(NULL, NULL, NULL);) 2025.11.13 09:12:19.592767 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:19.667604 [ 18771 ] {787176b4-a7b5-4ac7-95db-42268d4f3065} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 412, line 413) (in query: SELECT dateTimeToSnowflake(NULL, NULL, NULL);) 2025.11.13 09:12:19.672786 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.040263 [ 18771 ] {d4c22eac-f0a9-470d-a480-dca7b1a0619c} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 417, line 418) (in query: SELECT decodeHTMLComponent(NULL, NULL, NULL);) 2025.11.13 09:12:20.054363 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.077566 [ 18771 ] {d50bb603-3af8-4a01-8585-f8ad0b655aaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 418, line 419) (in query: SELECT decodeURLComponent(NULL, NULL, NULL);) 2025.11.13 09:12:20.082853 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.110627 [ 18771 ] {e3b77e61-1d14-4a51-984b-28f873aae333} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 419, line 420) (in query: SELECT decodeURLFormComponent(NULL, NULL, NULL);) 2025.11.13 09:12:20.115626 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.144203 [ 18771 ] {075a9b6d-27a5-4c34-bfdb-d7af0f89c27f} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 420, line 421) (in query: SELECT decodeXMLComponent(NULL, NULL, NULL);) 2025.11.13 09:12:20.149842 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.303630 [ 18771 ] {1303dce5-0620-4b30-8a15-a9afa7420b98} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 422, line 423) (in query: SELECT defaultProfiles(NULL, NULL, NULL);) 2025.11.13 09:12:20.316763 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.340194 [ 18771 ] {efe82962-e5e8-40e8-9e9a-c250144818cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 423, line 424) (in query: SELECT defaultRoles(NULL, NULL, NULL);) 2025.11.13 09:12:20.364519 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.392782 [ 18771 ] {05bd1f1b-f818-410b-9399-5d9334205068} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 424, line 425) (in query: SELECT defaultValueOfArgumentType(NULL, NULL, NULL);) 2025.11.13 09:12:20.401857 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.424397 [ 18771 ] {244cf85f-07d5-45a7-9d15-832874100afb} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 425, line 426) (in query: SELECT defaultValueOfTypeName(NULL, NULL, NULL);) 2025.11.13 09:12:20.429931 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.454842 [ 18771 ] {095b8b7a-9d37-4997-bb1b-af8c423e7b1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 426, line 427) (in query: SELECT degrees(NULL, NULL, NULL);) 2025.11.13 09:12:20.461511 [ 10181 ] {666e81c1-363e-46cc-afd5-351ba7c14daa} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 870, line 872) (in query: SELECT min2(NULL, NULL, NULL);) 2025.11.13 09:12:20.461984 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.468031 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.488418 [ 18771 ] {3a22d2c8-59c2-4f07-b296-5fc01ebf4b15} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 427, line 428) (in query: SELECT deltaSum(NULL, NULL, NULL);) 2025.11.13 09:12:20.494147 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.553418 [ 18771 ] {80dbb5d7-1d87-40fc-9ed8-7655fa3c78e7} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 428, line 429) (in query: SELECT deltaSumTimestamp(NULL, NULL, NULL);) 2025.11.13 09:12:20.576520 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.584693 [ 10181 ] {552e9e35-0006-4906-a0f4-63317695cb0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 872, line 874) (in query: SELECT minSampleSizeContinous(NULL, NULL, NULL);) 2025.11.13 09:12:20.589761 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.613387 [ 10181 ] {ca0ae994-2192-4ae1-8e51-203fd2aea630} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 873, line 875) (in query: SELECT minSampleSizeContinuous(NULL, NULL, NULL);) 2025.11.13 09:12:20.615856 [ 18771 ] {da672643-f01d-45a3-ac16-7243bedf76c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 429, line 430) (in query: SELECT demangle(NULL, NULL, NULL);) 2025.11.13 09:12:20.618415 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.633809 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.640757 [ 10181 ] {91614548-b056-4fcc-a3f3-f504042db935} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 874, line 876) (in query: SELECT minSampleSizeConversion(NULL, NULL, NULL);) 2025.11.13 09:12:20.645216 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.672967 [ 18771 ] {8db0c7c1-0f70-4f40-9397-d9d9188660cd} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 430, line 431) (in query: SELECT denseRank(NULL, NULL, NULL);) 2025.11.13 09:12:20.681093 [ 10181 ] {7ed1ec42-8d9d-46b9-85fe-963b33554cc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 875, line 877) (in query: SELECT minus(NULL, NULL, NULL);) 2025.11.13 09:12:20.681306 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:12:20.685649 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.708716 [ 10181 ] {dae149ef-a54a-40f7-8c20-bb7bf4df6c6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 876, line 878) (in query: SELECT mismatches(NULL, NULL, NULL);) 2025.11.13 09:12:20.714605 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.735683 [ 10181 ] {e1833ab6-e533-4d9c-b552-ae6ca66c6ba4} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 877, line 879) (in query: SELECT mod(NULL, NULL, NULL);) 2025.11.13 09:12:20.740178 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.765712 [ 10181 ] {e76948c8-0f41-46b4-8916-3c1998bb6280} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 878, line 880) (in query: SELECT modulo(NULL, NULL, NULL);) 2025.11.13 09:12:20.771162 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.797482 [ 10181 ] {8357c4d5-f282-4cea-a55b-6f310b61e68a} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 879, line 881) (in query: SELECT moduloLegacy(NULL, NULL, NULL);) 2025.11.13 09:12:20.802684 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.811766 [ 18771 ] {e96e8a9d-23de-4b80-9df2-9afb2c7c31d6} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 431, line 432) (in query: SELECT dense_rank(NULL, NULL, NULL);) 2025.11.13 09:12:20.822937 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:12:20.831373 [ 10181 ] {5596e41c-81dc-4f05-857a-c9e868e33043} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 880, line 882) (in query: SELECT moduloOrZero(NULL, NULL, NULL);) 2025.11.13 09:12:20.838400 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.862548 [ 10181 ] {501fb85c-4a92-4d74-99ec-5a8ce8c7e89c} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 881, line 883) (in query: SELECT monthName(NULL, NULL, NULL);) 2025.11.13 09:12:20.868921 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.892499 [ 18771 ] {4a0d830d-c55e-4999-a18b-ffbffa669db0} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 432, line 433) (in query: SELECT detectCharset(NULL, NULL, NULL);) 2025.11.13 09:12:20.897092 [ 18771 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:12:20.925427 [ 18771 ] {8c480144-4f07-4326-9fd5-28fce38d6957} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 433, line 434) (in query: SELECT detectLanguage(NULL, NULL, NULL);) 2025.11.13 09:12:20.930351 [ 18771 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:12:20.935417 [ 10181 ] {84eebe86-eaea-4a9e-b03e-130a36057094} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 882, line 884) (in query: SELECT mortonDecode(NULL, NULL, NULL);) 2025.11.13 09:12:20.940036 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:20.956943 [ 18771 ] {0d349489-3c4d-430a-8ddd-a8f71da4c448} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 434, line 435) (in query: SELECT detectLanguageMixed(NULL, NULL, NULL);) 2025.11.13 09:12:20.961800 [ 18771 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:12:21.066234 [ 18771 ] {efb8b15f-76c4-4012-b136-f70fa1755159} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 435, line 436) (in query: SELECT detectLanguageUnknown(NULL, NULL, NULL);) 2025.11.13 09:12:21.074348 [ 18771 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:12:21.097980 [ 18771 ] {2f6d1754-4a71-4018-9da1-7475ce14cc67} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 436, line 437) (in query: SELECT detectProgrammingLanguage(NULL, NULL, NULL);) 2025.11.13 09:12:21.102435 [ 18771 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:12:21.128691 [ 18771 ] {6565e4ca-1815-425d-9402-9f33a70d9d79} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 437, line 438) (in query: SELECT detectTonality(NULL, NULL, NULL);) 2025.11.13 09:12:21.133430 [ 18771 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:12:21.178253 [ 18771 ] {1bfcccf8-82be-4829-98b7-756d3a90f9fd} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 438, line 439) (in query: SELECT dictGet(NULL, NULL, NULL);) 2025.11.13 09:12:21.194973 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:21.216138 [ 18771 ] {2fc41711-b29b-4d2f-96b5-f7c253579408} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 439, line 440) (in query: SELECT dictGetAll(NULL, NULL, NULL);) 2025.11.13 09:12:21.220778 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:21.237578 [ 10181 ] {0da3576a-cad9-421a-a8a6-d7050ab74e58} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 888, line 890) (in query: SELECT multiMatchAllIndices(NULL, NULL, NULL);) 2025.11.13 09:12:21.244766 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.249292 [ 18771 ] {e99c35a3-456e-4541-999a-0e7258799b0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 440, line 441) (in query: SELECT dictGetChildren(NULL, NULL, NULL);) 2025.11.13 09:12:21.254408 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.267765 [ 10181 ] {fadb1d37-e238-4555-87e5-3e93471f6707} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 889, line 891) (in query: SELECT multiMatchAny(NULL, NULL, NULL);) 2025.11.13 09:12:21.285776 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.342311 [ 10181 ] {15bfff89-5726-4295-a4dd-620456e2e716} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 890, line 892) (in query: SELECT multiMatchAnyIndex(NULL, NULL, NULL);) 2025.11.13 09:12:21.349199 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.371929 [ 10181 ] {74f0a390-204e-431c-9ce8-af286c73d589} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 891, line 893) (in query: SELECT multiSearchAllPositions(NULL, NULL, NULL);) 2025.11.13 09:12:21.465926 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.485416 [ 10181 ] {eebdcbbc-6eed-46ec-9062-65c2318b3aca} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 892, line 894) (in query: SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:21.519848 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.544901 [ 10181 ] {00e4aa0c-6dad-4546-9416-f19ec61cba60} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 893, line 895) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:21.549784 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.572506 [ 10181 ] {63595692-d1da-44f3-82ee-68506d62bea6} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 894, line 896) (in query: SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:21.578421 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.599689 [ 10181 ] {90f8d2e1-c6d8-4b5e-a5bf-267f4b8dba13} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 895, line 897) (in query: SELECT multiSearchAny(NULL, NULL, NULL);) 2025.11.13 09:12:21.600154 [ 18771 ] {2426c487-70b5-476f-b01c-29a20bc091d3} executeQuery: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 445, line 446) (in query: SELECT dictGetDescendants(NULL, NULL, NULL);) 2025.11.13 09:12:21.604533 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.606146 [ 18771 ] {} TCPHandler: Code: 1. DB::Exception: Expected const String column: In scope SELECT dictGetDescendants(NULL, NULL, NULL). (UNSUPPORTED_METHOD) 2025.11.13 09:12:21.631541 [ 10181 ] {c18989cc-14bf-44b8-a126-7a988106ea9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 896, line 898) (in query: SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:21.684931 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.710868 [ 10181 ] {25b00bf1-84ab-4c42-9599-43e99b352746} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 897, line 899) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:21.718395 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.730373 [ 19243 ] {3cd58813-d61c-49b3-af80-cd4dbc853a94} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47392) (comment: 00999_nullable_nested_types_4877.sql) (query 12, line 16) (in query: SELECT a from l LEFT JOIN r USING a ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1293: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec912 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:21.737031 [ 19243 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1293: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec912 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:21.740202 [ 10181 ] {2dc1dbcb-76f8-4036-9319-1d36dafa5edf} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 898, line 900) (in query: SELECT multiSearchAnyUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:21.745283 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.773774 [ 10181 ] {c3915b11-e261-4b94-b42b-a24e2e1681ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 899, line 901) (in query: SELECT multiSearchFirstIndex(NULL, NULL, NULL);) 2025.11.13 09:12:21.778985 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.804111 [ 10181 ] {d289f84d-fc53-44b9-b3f9-70ebba5f5432} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 900, line 902) (in query: SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:21.809466 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.813118 [ 18771 ] {3714499e-a29f-4c71-9072-d8efb5d4331b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 450, line 451) (in query: SELECT dictGetHierarchy(NULL, NULL, NULL);) 2025.11.13 09:12:21.829847 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.833382 [ 10181 ] {ce381428-ad7c-4f38-a78f-fa23f7d792f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 901, line 903) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:21.846723 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.865285 [ 10181 ] {650f9790-3c64-4bd1-9abb-df116b8e0177} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 902, line 904) (in query: SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:21.878085 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.895913 [ 10181 ] {c4060b23-ce89-49c6-afbb-759d572a05b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 903, line 905) (in query: SELECT multiSearchFirstPosition(NULL, NULL, NULL);) 2025.11.13 09:12:21.902154 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.925475 [ 10181 ] {8d8e783d-13e6-4e5f-a53f-a91508a2fee8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 904, line 906) (in query: SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:21.929829 [ 19606 ] {927fe22a-fb6b-4490-b7f3-04dab46f7edb} executeQuery: Code: 520. DB::Exception: Cannot drop/detach dictionary test_1x5lm04b.02181_test_dictionary as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53120) (comment: 02181_dictionary_attach_detach.sql) (query 6, line 22) (in query: DETACH TABLE 02181_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:162: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x00000000384411d4 5. ./build_docker/./src/Storages/StorageDictionary.cpp:175: DB::StorageDictionary::checkTableCanBeDetached() const @ 0x000000003844133a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a699f0 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:12:21.933426 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.934160 [ 19606 ] {} TCPHandler: Code: 520. DB::Exception: Cannot drop/detach dictionary test_1x5lm04b.02181_test_dictionary as table, use DROP DICTIONARY or DETACH DICTIONARY query instead. (CANNOT_DETACH_DICTIONARY_AS_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageDictionary.cpp:162: DB::StorageDictionary::checkTableCanBeDropped(std::shared_ptr) const @ 0x00000000384411d4 5. ./build_docker/./src/Storages/StorageDictionary.cpp:175: DB::StorageDictionary::checkTableCanBeDetached() const @ 0x000000003844133a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a699f0 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:12:21.950569 [ 19606 ] {263c5a8f-bd55-4a05-a038-ab403b495c22} executeQuery: Code: 80. DB::Exception: Cannot ATTACH TABLE test_1x5lm04b.`02181_test_dictionary`, it is a Dictionary. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53120) (comment: 02181_dictionary_attach_detach.sql) (query 7, line 23) (in query: ATTACH TABLE 02181_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1564: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000032a01624 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:12:21.954088 [ 19606 ] {} TCPHandler: Code: 80. DB::Exception: Cannot ATTACH TABLE test_1x5lm04b.`02181_test_dictionary`, it is a Dictionary. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1564: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000032a01624 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:12:21.954435 [ 10181 ] {0fd24966-e4e0-4999-935f-1d6e72118774} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 905, line 907) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:21.959220 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:21.984259 [ 10181 ] {62047aaa-d054-401f-b889-5dc33d156533} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 906, line 908) (in query: SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:22.058056 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:22.081608 [ 10181 ] {2f7c00de-5aca-4a3f-aef0-9c990e2f8764} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 907, line 909) (in query: SELECT multiply(NULL, NULL, NULL);) 2025.11.13 09:12:22.188754 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:22.817292 [ 10181 ] {00f2856a-cc78-4947-8cf3-b57632be3636} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 914, line 916) (in query: SELECT negate(NULL, NULL, NULL);) 2025.11.13 09:12:22.822691 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:22.849148 [ 10181 ] {06900ed2-8036-4b49-9ea5-0dcd75cf69ba} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 915, line 917) (in query: SELECT neighbor(NULL, NULL, NULL);) 2025.11.13 09:12:22.854110 [ 10181 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:12:22.947164 [ 10181 ] {abf2e4bd-70ca-47cc-b2b5-b974b008ea45} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 917, line 919) (in query: SELECT netloc(NULL, NULL, NULL);) 2025.11.13 09:12:22.953095 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:22.969955 [ 18771 ] {7a773ff5-0b54-4cbd-90af-63960def243a} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 463, line 464) (in query: SELECT dictGetOrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:22.974797 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:22.977101 [ 10181 ] {a329a682-8e71-411a-b9ac-2a26ed6468b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 918, line 920) (in query: SELECT ngramDistance(NULL, NULL, NULL);) 2025.11.13 09:12:22.984045 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:23.003579 [ 10181 ] {707b10d7-f734-468b-a489-542c1b504f48} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 919, line 921) (in query: SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:23.003579 [ 18771 ] {c25a3adf-c468-4ae5-9dc7-e49e1d0e02e9} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 464, line 465) (in query: SELECT dictGetOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:23.012240 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:23.014179 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:23.036551 [ 10181 ] {cf2c2b03-7b52-4860-a186-918eea80dd7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 920, line 922) (in query: SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:23.042227 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:23.066895 [ 10181 ] {a104ae33-1527-4e8a-abe2-00afa62e9a8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 921, line 923) (in query: SELECT ngramDistanceUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:23.082197 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:23.249781 [ 19619 ] {17e783e6-d7d2-410d-a152-8bf63ff619ec} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53128) (comment: 02815_range_dict_no_direct_join.sql) (query 13, line 35) (in query: SELECT id, amount FROM ids INNER JOIN discounts_dict ON id = advertiser_id ORDER BY id, amount SETTINGS join_algorithm = 'direct';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1293: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec912 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:23.254249 [ 19619 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1293: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec912 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:23.493263 [ 10181 ] {4a1120e8-3bc2-417d-84df-f403c737c353} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 930, line 932) (in query: SELECT ngramSearch(NULL, NULL, NULL);) 2025.11.13 09:12:23.499274 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:23.520477 [ 10181 ] {f8fd49a2-cb0e-4da3-a430-6cf86e037e17} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 931, line 933) (in query: SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:23.525864 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:23.547464 [ 10181 ] {c0abdf32-dc0a-4f61-b912-31e4e4fa7af3} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 932, line 934) (in query: SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:23.553867 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:23.562213 [ 16381 ] {479d2a01-1e33-4692-acca-63ee2dae6d44} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53158) (comment: 02490_replacing_merge_tree_is_deleted_column.sql) (query 10, line 16) (in query: CREATE TABLE test (`uid` String, `version` UInt32, `is_deleted` UInt8) ENGINE = ReplacingMergeTree(version) ORDER BY uid SETTINGS clean_deleted_rows = 'Always', allow_experimental_replacing_merge_with_cleanup = 1, index_granularity = 26211, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 37675014, compact_parts_max_granules_to_buffer = 82, compact_parts_merge_max_bytes_to_prefetch_part = 3486299, merge_max_block_size = 1003, old_parts_lifetime = 156., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 81, min_merge_bytes_to_use_direct_io = 4952658811, index_granularity_bytes = 4403948, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 20663, primary_key_compress_block_size = 40972, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:23.572445 [ 10181 ] {d9d763e8-1170-4a1b-979b-0c0b7d1831f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 933, line 935) (in query: SELECT ngramSearchUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:23.573666 [ 16381 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:23.577713 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:23.827194 [ 18771 ] {d9ca35d1-7c31-4502-a10d-074fffee049c} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 479, line 480) (in query: SELECT displayName(NULL, NULL, NULL);) 2025.11.13 09:12:23.832327 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:23.920721 [ 18771 ] {fb9f406f-23ff-447f-b045-e6df4e989264} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 480, line 481) (in query: SELECT distanceL1(NULL, NULL, NULL);) 2025.11.13 09:12:23.925977 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:23.953114 [ 18771 ] {af68898a-a599-46f8-9974-6147e0c21ecc} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 481, line 482) (in query: SELECT distanceL2(NULL, NULL, NULL);) 2025.11.13 09:12:23.968004 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.024689 [ 18771 ] {0063125f-fbf5-4998-beaa-070d95d8f5df} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 482, line 483) (in query: SELECT distanceL2Squared(NULL, NULL, NULL);) 2025.11.13 09:12:24.029834 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.031652 [ 16194 ] {7a8434e7-a473-4066-9c3c-08707bca33d3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=842). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47336) (comment: 00826_cross_to_inner_join.sql) (query 51, line 64) (in query: EXPLAIN SYNTAX select * from t1_00826 cross join t2_00826 where t1_00826.a = t1_00826.b order by all;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:24.037318 [ 16194 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=842). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:24.040639 [ 10181 ] {1b79e768-edfa-4c77-b85a-32ce162bc04e} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 938, line 940) (in query: SELECT ngrams(NULL, NULL, NULL);) 2025.11.13 09:12:24.045612 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.058352 [ 18771 ] {2b4baa9b-f7dc-4822-903d-7ef64663b30b} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 483, line 484) (in query: SELECT distanceLinf(NULL, NULL, NULL);) 2025.11.13 09:12:24.064499 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.149922 [ 10181 ] {336bc6e9-4251-44c1-b5a4-7ba5a324593e} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 939, line 941) (in query: SELECT nonNegativeDerivative(NULL, NULL, NULL);) 2025.11.13 09:12:24.158913 [ 10181 ] {} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.11.13 09:12:24.191107 [ 10181 ] {e356f348-cc69-49eb-b8e4-57d660625131} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 940, line 942) (in query: SELECT normL1(NULL, NULL, NULL);) 2025.11.13 09:12:24.196387 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.218572 [ 16047 ] {8c7ce5fc-8325-43ee-b941-d5031d388760} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44348) (comment: 00826_cross_to_inner_join.sql) (in query: DROP DATABASE IF EXISTS test_t1bgv3bf SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:12:24.219831 [ 10181 ] {20159052-c295-43cd-82f2-1fbd9c3c5896} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 941, line 943) (in query: SELECT normL2(NULL, NULL, NULL);) 2025.11.13 09:12:24.221972 [ 16047 ] {8c7ce5fc-8325-43ee-b941-d5031d388760} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:24.225964 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.311828 [ 10181 ] {d757eaba-7dac-4bb1-876e-21ecd3636313} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 942, line 944) (in query: SELECT normL2Squared(NULL, NULL, NULL);) 2025.11.13 09:12:24.318340 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.339504 [ 10181 ] {24a20d11-b3f9-4109-8986-1c7284033778} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 943, line 945) (in query: SELECT normLinf(NULL, NULL, NULL);) 2025.11.13 09:12:24.419674 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.442953 [ 10181 ] {d2333615-8b5f-49c2-b1b0-c37c5bcd6e66} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 944, line 946) (in query: SELECT normLp(NULL, NULL, NULL);) 2025.11.13 09:12:24.455109 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.471116 [ 10181 ] {477de67e-4c60-4b80-b52e-d01ac70b9c9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 945, line 947) (in query: SELECT normalizeL1(NULL, NULL, NULL);) 2025.11.13 09:12:24.483214 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.535055 [ 10181 ] {c3be7a42-3448-4296-ab36-471f0e89361e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 946, line 948) (in query: SELECT normalizeL2(NULL, NULL, NULL);) 2025.11.13 09:12:24.547185 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.568094 [ 10181 ] {5004be34-d2ff-46da-8c0c-f57c8cde0ba6} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 947, line 949) (in query: SELECT normalizeLinf(NULL, NULL, NULL);) 2025.11.13 09:12:24.579869 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.594448 [ 18771 ] {f04c8eb6-b1da-4b83-9f86-1e9a881a3cc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 488, line 489) (in query: SELECT divide(NULL, NULL, NULL);) 2025.11.13 09:12:24.597456 [ 10181 ] {8374d8cd-f9c0-4658-83e8-67feb6ee75b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 948, line 950) (in query: SELECT normalizeLp(NULL, NULL, NULL);) 2025.11.13 09:12:24.606778 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.609697 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.625581 [ 10181 ] {7808565a-6892-4e08-ad1e-3a03df22f449} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 949, line 951) (in query: SELECT normalizeQuery(NULL, NULL, NULL);) 2025.11.13 09:12:24.633630 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.657657 [ 10181 ] {420aa776-f98e-4ccf-be56-7931d5b0384a} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 950, line 952) (in query: SELECT normalizeQueryKeepNames(NULL, NULL, NULL);) 2025.11.13 09:12:24.664159 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.673085 [ 18771 ] {278302fb-5a4a-4b6f-8026-1824087bd1b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 490, line 491) (in query: SELECT domain(NULL, NULL, NULL);) 2025.11.13 09:12:24.680378 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.684541 [ 10181 ] {3d968365-3c77-4e13-8e67-a2319922f174} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 951, line 953) (in query: SELECT normalizeUTF8NFC(NULL, NULL, NULL);) 2025.11.13 09:12:24.689307 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.703108 [ 18771 ] {1c669704-c4f3-4761-87cf-9cfb25a5778e} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 491, line 492) (in query: SELECT domainRFC(NULL, NULL, NULL);) 2025.11.13 09:12:24.709951 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.711703 [ 10181 ] {0655c76a-0a50-4c17-b598-6fba8e7f3a78} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 952, line 954) (in query: SELECT normalizeUTF8NFD(NULL, NULL, NULL);) 2025.11.13 09:12:24.717513 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.734976 [ 18771 ] {385caf9a-96a1-40aa-905d-c63c98a044c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 492, line 493) (in query: SELECT domainWithoutWWW(NULL, NULL, NULL);) 2025.11.13 09:12:24.741738 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.769245 [ 18771 ] {69ed89d2-243c-4672-97af-66c31b7261eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 493, line 494) (in query: SELECT domainWithoutWWWRFC(NULL, NULL, NULL);) 2025.11.13 09:12:24.776164 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.799511 [ 18771 ] {8d17adf4-fe47-4b9c-b359-3d60e163e494} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 494, line 495) (in query: SELECT dotProduct(NULL, NULL, NULL);) 2025.11.13 09:12:24.806691 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.827098 [ 18771 ] {07333d91-eca1-4c3d-85b1-285a997ae75d} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 495, line 496) (in query: SELECT dumpColumnStructure(NULL, NULL, NULL);) 2025.11.13 09:12:24.831856 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.833985 [ 10181 ] {13287dd3-e290-437f-b2f2-b301f8ad2f67} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 953, line 955) (in query: SELECT normalizeUTF8NFKC(NULL, NULL, NULL);) 2025.11.13 09:12:24.839899 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.857366 [ 18771 ] {cb1d1cef-9554-48bf-86b8-fcc8c4412c6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 496, line 497) (in query: SELECT dynamicElement(NULL, NULL, NULL);) 2025.11.13 09:12:24.863022 [ 10181 ] {3a09f122-4bac-4ced-b23b-b6a5975b41c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 954, line 956) (in query: SELECT normalizeUTF8NFKD(NULL, NULL, NULL);) 2025.11.13 09:12:24.864055 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.875506 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.893284 [ 18771 ] {ac822b0a-5560-4440-9951-634860cd39c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 497, line 498) (in query: SELECT dynamicType(NULL, NULL, NULL);) 2025.11.13 09:12:24.899384 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.925974 [ 10181 ] {bf1aa7df-b9d0-4ad2-8f4d-6190b6c4536e} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 955, line 957) (in query: SELECT normalizedQueryHash(NULL, NULL, NULL);) 2025.11.13 09:12:24.938054 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.941064 [ 18771 ] {9146cd3c-b477-4f51-a6b9-37d041a4a48e} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 498, line 499) (in query: SELECT e(NULL, NULL, NULL);) 2025.11.13 09:12:24.949806 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.959899 [ 10181 ] {56274135-4ccf-4871-bae1-93cb6698250b} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 956, line 958) (in query: SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL);) 2025.11.13 09:12:24.964897 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:24.985527 [ 10181 ] {f9c60516-0d50-4f32-af1a-0d00ea243dde} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 957, line 959) (in query: SELECT not(NULL, NULL, NULL);) 2025.11.13 09:12:24.998774 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.020318 [ 18771 ] {c2355ed1-e805-45ad-8825-4db52fe40e50} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 499, line 500) (in query: SELECT editDistance(NULL, NULL, NULL);) 2025.11.13 09:12:25.033482 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.053399 [ 18771 ] {a2cf604e-7eca-4870-ad8a-3d2449c90ffc} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 500, line 501) (in query: SELECT editDistanceUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:25.058715 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.072087 [ 10181 ] {ca80125f-06e4-4a73-8df4-07eb680eb9e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 958, line 960) (in query: SELECT notEmpty(NULL, NULL, NULL);) 2025.11.13 09:12:25.081690 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.082261 [ 18771 ] {335cdf3e-ab1a-46ea-8c5c-8bed6d1e47ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 501, line 502) (in query: SELECT empty(NULL, NULL, NULL);) 2025.11.13 09:12:25.089908 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.108313 [ 10181 ] {c1109474-2658-40e5-8174-3f1ca8122300} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 959, line 961) (in query: SELECT notEquals(NULL, NULL, NULL);) 2025.11.13 09:12:25.114465 [ 18771 ] {c423e5f9-1ead-4734-b5df-dfef5fd67a29} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 502, line 503) (in query: SELECT emptyArrayDate(NULL, NULL, NULL);) 2025.11.13 09:12:25.119741 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.136643 [ 10181 ] {1d17c330-b0c4-4570-8a3d-a0354d01992f} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 960, line 962) (in query: SELECT notILike(NULL, NULL, NULL);) 2025.11.13 09:12:25.144112 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.155669 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.163619 [ 10181 ] {e2441906-7ba3-4850-afc9-f35b14a09f5a} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 961, line 963) (in query: SELECT notIn(NULL, NULL, NULL);) 2025.11.13 09:12:25.171914 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.188897 [ 18771 ] {47194afa-d8ec-45f5-932f-d6fea6b7cd1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 503, line 504) (in query: SELECT emptyArrayDateTime(NULL, NULL, NULL);) 2025.11.13 09:12:25.189281 [ 10181 ] {216062f8-772d-4b10-a821-ffab93e0ddbd} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 962, line 964) (in query: SELECT notInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:25.194203 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.203281 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.216456 [ 10181 ] {12ded93c-52eb-4ecf-9092-7421f3f0239c} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 963, line 965) (in query: SELECT notLike(NULL, NULL, NULL);) 2025.11.13 09:12:25.219250 [ 18771 ] {800a3dfe-1aba-42f8-b36b-be808aad3612} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 504, line 505) (in query: SELECT emptyArrayFloat32(NULL, NULL, NULL);) 2025.11.13 09:12:25.228741 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.233181 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.248984 [ 18771 ] {23f1d8d7-2d06-4154-a278-f043e51c9167} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 505, line 506) (in query: SELECT emptyArrayFloat64(NULL, NULL, NULL);) 2025.11.13 09:12:25.249203 [ 10181 ] {21b0388e-4ffe-4d50-a88c-84c6a14a942a} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 964, line 966) (in query: SELECT notNullIn(NULL, NULL, NULL);) 2025.11.13 09:12:25.259642 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.282838 [ 10181 ] {309e79fa-e003-413a-83cd-ce12385dd2ae} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 965, line 967) (in query: SELECT notNullInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:25.289525 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.295413 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.377405 [ 18771 ] {6607edb2-7c2b-4ca8-b8e4-5aabc0f2b96c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 506, line 507) (in query: SELECT emptyArrayInt16(NULL, NULL, NULL);) 2025.11.13 09:12:25.388724 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.455481 [ 18771 ] {1b7f1192-d442-4286-b642-75498a433bf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 507, line 508) (in query: SELECT emptyArrayInt32(NULL, NULL, NULL);) 2025.11.13 09:12:25.470082 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.484784 [ 18771 ] {585ad919-3a10-471e-b024-eae39e3911b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 508, line 509) (in query: SELECT emptyArrayInt64(NULL, NULL, NULL);) 2025.11.13 09:12:25.494653 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.506570 [ 10181 ] {7e9435b6-08a8-433b-9e3b-507a0eae3d36} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 969, line 971) (in query: SELECT now(NULL, NULL, NULL);) 2025.11.13 09:12:25.512059 [ 18771 ] {9ae643cc-1afa-4d21-8802-5610ddcad7b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 509, line 510) (in query: SELECT emptyArrayInt8(NULL, NULL, NULL);) 2025.11.13 09:12:25.513864 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.563863 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.594185 [ 18771 ] {41e341fe-0005-4035-9fd9-3c47b9372b93} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 510, line 511) (in query: SELECT emptyArrayString(NULL, NULL, NULL);) 2025.11.13 09:12:25.599673 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.622010 [ 19606 ] {36011194-d280-46a8-9194-09cad9010e33} PostgreSQLConnectionPool: Connection error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? 2025.11.13 09:12:25.622761 [ 19606 ] {36011194-d280-46a8-9194-09cad9010e33} PostgreSQLConnectionPool: Connection error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? 2025.11.13 09:12:25.628974 [ 18771 ] {861e740f-1c45-4d6e-91fd-b321b275bc01} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 511, line 512) (in query: SELECT emptyArrayToSingle(NULL, NULL, NULL);) 2025.11.13 09:12:25.638174 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.760181 [ 10181 ] {a6eca802-0d7e-47dc-a040-1c92f753f8d5} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 972, line 974) (in query: SELECT nth_value(NULL, NULL, NULL);) 2025.11.13 09:12:25.764747 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.787236 [ 18771 ] {ef0302c1-0943-4f2b-9edd-1562cc22da2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 512, line 513) (in query: SELECT emptyArrayUInt16(NULL, NULL, NULL);) 2025.11.13 09:12:25.787380 [ 10181 ] {7e931408-0c51-4519-8d2f-9e72b524fa89} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 973, line 975) (in query: SELECT ntile(NULL, NULL, NULL);) 2025.11.13 09:12:25.791922 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.804418 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.819133 [ 10181 ] {7f43133f-f71f-4a6e-bfe5-67536addfa50} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 974, line 976) (in query: SELECT nullIf(NULL, NULL, NULL);) 2025.11.13 09:12:25.824512 [ 18771 ] {af5723d5-29d6-4be1-be5f-8bf15e31747b} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 513, line 514) (in query: SELECT emptyArrayUInt32(NULL, NULL, NULL);) 2025.11.13 09:12:25.824697 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.831875 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.844480 [ 10181 ] {ce229868-d477-449d-a4e5-93cd0e9ed359} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 975, line 977) (in query: SELECT nullIn(NULL, NULL, NULL);) 2025.11.13 09:12:25.849997 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.863194 [ 18771 ] {04f88ffa-525b-4469-99c8-95caf2c7e56a} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 514, line 515) (in query: SELECT emptyArrayUInt64(NULL, NULL, NULL);) 2025.11.13 09:12:25.869829 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.869834 [ 10181 ] {19d40868-83e6-4b85-bc73-a7dfcc434c32} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 976, line 978) (in query: SELECT nullInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:25.875041 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.885393 [ 16390 ] {79579736-cb0b-4a9e-9232-921d3aa7bd52} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53280) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 9, line 13) (in query: -- constant ignore will be pruned by part pruner. ignore(*) is used. SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:12:25.889794 [ 16390 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:12:25.934789 [ 16390 ] {f40e44bc-45ef-4993-bd74-5b2da83c7948} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53280) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (query 10, line 15) (in query: SELECT count() FROM merge_tree WHERE not ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:12:25.937987 [ 16390 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 900.00 thousand, current rows: 1.00 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:12:25.947643 [ 18771 ] {a7649207-5e45-4bba-8bd5-b05abc76f9bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 515, line 516) (in query: SELECT emptyArrayUInt8(NULL, NULL, NULL);) 2025.11.13 09:12:25.953100 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:25.977508 [ 18771 ] {a47bad04-6636-455c-b838-1e1ffc0edae6} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 516, line 517) (in query: SELECT enabledProfiles(NULL, NULL, NULL);) 2025.11.13 09:12:25.981974 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.011615 [ 16047 ] {44e77544-9f4b-49a4-9719-e0c8b524f6bb} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53328) (query 1, line 1) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038521118 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:12:26.058317 [ 19619 ] {59da45c4-a243-495b-a2af-2cd5ccb42637} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44396) (comment: 00971_merge_tree_uniform_read_distribution_and_max_rows_to_read.sql) (in query: DROP DATABASE IF EXISTS test_48xpvp3r SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:12:26.061607 [ 19619 ] {59da45c4-a243-495b-a2af-2cd5ccb42637} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:26.098606 [ 16047 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038521118 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:12:26.110018 [ 18771 ] {2c84b951-cd72-419b-96ce-17e0457ced28} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 517, line 518) (in query: SELECT enabledRoles(NULL, NULL, NULL);) 2025.11.13 09:12:26.114908 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.185487 [ 18771 ] {c56c0c8e-875c-4706-a28a-1b39481a6e80} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 518, line 519) (in query: SELECT encodeURLComponent(NULL, NULL, NULL);) 2025.11.13 09:12:26.192283 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.222266 [ 18771 ] {8b69aa74-e265-4205-80bc-133d2d3695bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 519, line 520) (in query: SELECT encodeURLFormComponent(NULL, NULL, NULL);) 2025.11.13 09:12:26.232752 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.354851 [ 18771 ] {2d917833-7c0f-4862-b1f8-ab5c5b89c492} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 520, line 521) (in query: SELECT encodeXMLComponent(NULL, NULL, NULL);) 2025.11.13 09:12:26.372119 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.436749 [ 18771 ] {87b93e33-052e-4f45-ad6e-5c3cd617c95a} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 522, line 523) (in query: SELECT endsWith(NULL, NULL, NULL);) 2025.11.13 09:12:26.445511 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.477814 [ 18771 ] {0ad50e8a-e008-4ab9-92d7-e2f96fe621dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 523, line 524) (in query: SELECT endsWithUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:26.492457 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.535668 [ 19606 ] {36011194-d280-46a8-9194-09cad9010e33} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `127.121.0.1:5432` failed with error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53304) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (query 9, line 16) (in query: CREATE TABLE test_0kpn03c9.tablefunc01_without_schema AS postgresql('127.121.0.1:5432', 'postgres_db', 'postgres_table', 'postgres_user', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x00000000266f091f 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x000000002d82a73f 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000003887f2a2 5. ./build_docker/./src/TableFunctions/TableFunctionPostgreSQL.cpp:76: DB::(anonymous namespace)::TableFunctionPostgreSQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000268001ba 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:972: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d59b1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:26.539875 [ 19606 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `127.121.0.1:5432` failed with error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x00000000266f091f 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x000000002d82a73f 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:115: DB::StoragePostgreSQL::getTableStructureFromData(std::shared_ptr const&, String const&, String const&, std::shared_ptr const&) @ 0x000000003887f2a2 5. ./build_docker/./src/TableFunctions/TableFunctionPostgreSQL.cpp:76: DB::(anonymous namespace)::TableFunctionPostgreSQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000268001ba 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:972: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d59b1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:26.541376 [ 16381 ] {6ad2b493-1b99-41bf-9c01-af3052185eae} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53306) (comment: 00472_create_view_if_not_exists.sql) (query 6, line 8) (in query: DROP TABLE t_00472;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:12:26.547481 [ 16381 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:12:26.565885 [ 19606 ] {7af56c74-a90d-4b6b-b73f-bc40718580f4} mysqlxx::Pool: Failed to connect to MySQL (mysql_db@127.123.0.1:3306 as user mysql_user): mysqlxx::ConnectionFailed 2025.11.13 09:12:26.566372 [ 19606 ] {7af56c74-a90d-4b6b-b73f-bc40718580f4} Application: Connection to mysql_db@127.123.0.1:3306 as user mysql_user failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0) 2025.11.13 09:12:26.566714 [ 19606 ] {7af56c74-a90d-4b6b-b73f-bc40718580f4} Application: Connection to mysql failed 1 times 2025.11.13 09:12:26.567345 [ 19606 ] {7af56c74-a90d-4b6b-b73f-bc40718580f4} mysqlxx::Pool: Failed to connect to MySQL (mysql_db@127.123.0.1:3306 as user mysql_user): mysqlxx::ConnectionFailed 2025.11.13 09:12:26.567486 [ 19606 ] {7af56c74-a90d-4b6b-b73f-bc40718580f4} Application: Connection to mysql_db@127.123.0.1:3306 as user mysql_user failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0) 2025.11.13 09:12:26.567543 [ 19606 ] {7af56c74-a90d-4b6b-b73f-bc40718580f4} Application: Connection to mysql failed 2 times 2025.11.13 09:12:26.567876 [ 19606 ] {7af56c74-a90d-4b6b-b73f-bc40718580f4} mysqlxx::Pool: Failed to connect to MySQL (mysql_db@127.123.0.1:3306 as user mysql_user): mysqlxx::ConnectionFailed 2025.11.13 09:12:26.568002 [ 19606 ] {7af56c74-a90d-4b6b-b73f-bc40718580f4} Application: Connection to mysql_db@127.123.0.1:3306 as user mysql_user failed: mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0) 2025.11.13 09:12:26.568049 [ 19606 ] {7af56c74-a90d-4b6b-b73f-bc40718580f4} Application: Connection to mysql failed 3 times 2025.11.13 09:12:26.649065 [ 18771 ] {a8f429f8-1048-4649-9a1e-5fbdd4979cbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 525, line 526) (in query: SELECT equals(NULL, NULL, NULL);) 2025.11.13 09:12:26.657429 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.685972 [ 18771 ] {0253762b-6c31-4b7c-9222-859948f1bf4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 526, line 527) (in query: SELECT erf(NULL, NULL, NULL);) 2025.11.13 09:12:26.758284 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.788366 [ 18771 ] {babf5304-74bd-4af8-89e9-617f4b0a63ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 527, line 528) (in query: SELECT erfc(NULL, NULL, NULL);) 2025.11.13 09:12:26.845151 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.864535 [ 18771 ] {648dbf11-2eda-489f-90c6-5672a40d2fc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 528, line 529) (in query: SELECT errorCodeToName(NULL, NULL, NULL);) 2025.11.13 09:12:26.870456 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:26.935769 [ 18771 ] {cf47a1d2-a187-4d92-8e0e-49e7cea4a12d} executeQuery: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 529, line 530) (in query: SELECT estimateCompressionRatio(NULL, NULL, NULL);) 2025.11.13 09:12:26.940605 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.013048 [ 18771 ] {eeeef83d-85fc-4259-a428-03e9ce4b6ab0} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 531, line 532) (in query: SELECT exp(NULL, NULL, NULL);) 2025.11.13 09:12:27.020751 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.142320 [ 18771 ] {a3a54a2f-9a0c-4307-b92a-5f0c7b3c2ef9} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 532, line 533) (in query: SELECT exp10(NULL, NULL, NULL);) 2025.11.13 09:12:27.155667 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.179938 [ 18771 ] {7fca59cd-3721-4ccb-8e18-4d646df36fe7} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 533, line 534) (in query: SELECT exp2(NULL, NULL, NULL);) 2025.11.13 09:12:27.194793 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.279005 [ 18771 ] {765389a6-6b39-4ae5-ba1e-c29b4e83db0a} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 535, line 536) (in query: SELECT exponentialTimeDecayedAvg(NULL, NULL, NULL);) 2025.11.13 09:12:27.283673 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.310391 [ 18771 ] {860755ab-1e8d-4248-bab8-dd2761c806ab} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 536, line 537) (in query: SELECT exponentialTimeDecayedCount(NULL, NULL, NULL);) 2025.11.13 09:12:27.321233 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.340120 [ 18771 ] {0e202b7b-8faa-45cc-99fd-6cb1ddd31540} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 537, line 538) (in query: SELECT exponentialTimeDecayedMax(NULL, NULL, NULL);) 2025.11.13 09:12:27.387781 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.414359 [ 18771 ] {da5eb885-aaf8-4e36-94c4-ae53463c7bb2} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 538, line 539) (in query: SELECT exponentialTimeDecayedSum(NULL, NULL, NULL);) 2025.11.13 09:12:27.428565 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.445087 [ 18771 ] {2bbdc9b6-cc62-4f10-a60c-fdd2209d490f} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 539, line 540) (in query: SELECT extract(NULL, NULL, NULL);) 2025.11.13 09:12:27.462447 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.488651 [ 18771 ] {1f3f45f8-56ec-489c-8b58-e8ef1ed65c5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 540, line 541) (in query: SELECT extractAll(NULL, NULL, NULL);) 2025.11.13 09:12:27.498003 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.522542 [ 18771 ] {82609218-328c-426a-ba24-d41ace263fc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 541, line 542) (in query: SELECT extractAllGroups(NULL, NULL, NULL);) 2025.11.13 09:12:27.528951 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.554033 [ 18771 ] {1c603b44-2ba7-408b-b552-c9cc7437a4e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 542, line 543) (in query: SELECT extractAllGroupsHorizontal(NULL, NULL, NULL);) 2025.11.13 09:12:27.568713 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.660088 [ 18771 ] {cf59fc68-c44e-41a0-ba01-455cbdb6329f} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 543, line 544) (in query: SELECT extractAllGroupsVertical(NULL, NULL, NULL);) 2025.11.13 09:12:27.680318 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.709163 [ 18771 ] {151d4617-5632-47d2-8838-d7043d607f88} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 544, line 545) (in query: SELECT extractGroups(NULL, NULL, NULL);) 2025.11.13 09:12:27.717553 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:27.989708 [ 18771 ] {41239b5b-e078-4a66-b5ef-bc85106df974} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 547, line 548) (in query: SELECT extractTextFromHTML(NULL, NULL, NULL);) 2025.11.13 09:12:27.997966 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.019967 [ 18771 ] {d0736e4a-2d30-40a9-8b71-93b874ea44a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 548, line 549) (in query: SELECT extractURLParameter(NULL, NULL, NULL);) 2025.11.13 09:12:28.024177 [ 19606 ] {7af56c74-a90d-4b6b-b73f-bc40718580f4} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: mysql_db@127.123.0.1:3306 as user mysql_user, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53304) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (query 10, line 17) (in query: CREATE TABLE test_0kpn03c9.tablefunc02_without_schema AS mysql('127.123.0.1:3306', 'mysql_db', 'mysql_table', 'mysql_user', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000412aa414 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002fe0aafe 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000003886a67f 7. ./build_docker/./src/TableFunctions/TableFunctionMySQL.cpp:101: DB::(anonymous namespace)::TableFunctionMySQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000267fb1ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:972: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d59b1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:28.026648 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.050122 [ 19606 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: mysql_db@127.123.0.1:3306 as user mysql_user, ERROR 2002 : mysqlxx::ConnectionFailed: Can't connect to MySQL server on '127.123.0.1' (115) ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000412aa414 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002fe0aafe 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000003886a67f 7. ./build_docker/./src/TableFunctions/TableFunctionMySQL.cpp:101: DB::(anonymous namespace)::TableFunctionMySQL::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000267fb1ba 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:972: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d59b1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:28.067225 [ 18771 ] {9e88e3df-8721-4a20-a9f6-4f100bf8caf4} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 549, line 550) (in query: SELECT extractURLParameterNames(NULL, NULL, NULL);) 2025.11.13 09:12:28.073729 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.113966 [ 18771 ] {d9e271bd-35da-4efc-84b9-effbd0838532} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 550, line 551) (in query: SELECT extractURLParameters(NULL, NULL, NULL);) 2025.11.13 09:12:28.123353 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.220975 [ 18771 ] {f7a09d85-c26b-4cf6-9fda-1d5d0e26dc71} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 551, line 552) (in query: SELECT factorial(NULL, NULL, NULL);) 2025.11.13 09:12:28.232685 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.383854 [ 18771 ] {4b493eb9-77e2-4e0c-bf11-3c69ed374980} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 554, line 555) (in query: SELECT file(NULL, NULL, NULL);) 2025.11.13 09:12:28.391747 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.485178 [ 10181 ] {b511a8c7-d6a1-4e11-b288-80656d9953e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1007, line 1009) (in query: SELECT parseReadableSize(NULL, NULL, NULL);) 2025.11.13 09:12:28.507745 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.565011 [ 10181 ] {16a0db44-d275-4dff-969d-0ba5ea132969} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1008, line 1010) (in query: SELECT parseReadableSizeOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:28.570212 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.591867 [ 10181 ] {a70246cf-eaee-49c7-ad9a-ca06faed53b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1009, line 1011) (in query: SELECT parseReadableSizeOrZero(NULL, NULL, NULL);) 2025.11.13 09:12:28.602328 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.673279 [ 4528 ] {ab75c90d-897b-4e33-a244-3ed234676a29} executeQuery: Code: 47. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_u7x32bdu.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55302) (comment: 01297_alter_distributed.sql) (query 17, line 28) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, `__table1`.`dummy1` AS `dummy1` FROM `test_u7x32bdu`.`merge_distributed1` AS `__table1` WHERE `__table1`.`dummy1` != '' LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000031140d9f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:617: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000031128cf5 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112abcd 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1396: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eaa3 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000003113d802 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1498: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449f31 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:213: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x00000000305722d8 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:198: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030571dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc3db 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:28.689758 [ 4528 ] {} TCPHandler: Code: 47. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_u7x32bdu.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000031140d9f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:617: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000031128cf5 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112abcd 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1396: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eaa3 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000003113d802 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1498: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449f31 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:213: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x00000000305722d8 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:198: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030571dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc3db 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:28.694055 [ 18771 ] {557799a9-b9a7-456d-8028-246e57e98ee7} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 558, line 559) (in query: SELECT finalizeAggregation(NULL, NULL, NULL);) 2025.11.13 09:12:28.696521 [ 19621 ] {e8b775ad-2493-4029-8fba-1ac0f4c7b63c} executeQuery: Code: 47. DB::Exception: Received from localhost:9000. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_u7x32bdu.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000031140d9f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:617: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000031128cf5 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112abcd 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1396: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eaa3 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000003113d802 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1498: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449f31 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:213: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x00000000305722d8 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:198: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030571dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc3db 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 : While executing Remote. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53292) (comment: 01297_alter_distributed.sql) (query 17, line 28) (in query: select CounterID, dummy1 from merge_distributed where dummy1 <> '' limit 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:12:28.707632 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.779664 [ 19621 ] {} TCPHandler: Code: 47. DB::Exception: Received from localhost:9000. DB::Exception: Identifier '__table1.dummy1' cannot be resolved from table with name __table1. In scope SELECT __table1.CounterID AS CounterID, __table1.dummy1 AS dummy1 FROM test_u7x32bdu.merge_distributed1 AS __table1 WHERE __table1.dummy1 != '' LIMIT _CAST(10, 'UInt64'). Maybe you meant: ['__table1.dummy']. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000031140d9f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:617: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000031128cf5 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112abcd 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1396: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eaa3 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000003113d802 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1498: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449f31 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:213: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x00000000305722d8 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:198: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030571dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc3db 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 : While executing Remote. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:28.787171 [ 18771 ] {7f252821-acbb-4f92-a8bc-c7d3dca7850f} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 559, line 560) (in query: SELECT firstLine(NULL, NULL, NULL);) 2025.11.13 09:12:28.794583 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.826979 [ 18771 ] {37b8282a-f903-4ade-9c1e-6cf55bed15b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 560, line 561) (in query: SELECT firstSignificantSubdomain(NULL, NULL, NULL);) 2025.11.13 09:12:28.833063 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.858737 [ 10181 ] {687bf178-2a43-4ba4-9b8b-006aeea5e882} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1013, line 1015) (in query: SELECT path(NULL, NULL, NULL);) 2025.11.13 09:12:28.865454 [ 18771 ] {3ab428de-67f2-4dcc-863d-25f0cf06528e} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 561, line 562) (in query: SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL);) 2025.11.13 09:12:28.869224 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.882905 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.898181 [ 10181 ] {69ecf9db-3408-4995-94ef-c43ddd59d729} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1014, line 1016) (in query: SELECT pathFull(NULL, NULL, NULL);) 2025.11.13 09:12:28.905518 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.907146 [ 18771 ] {88cd6cf9-c67c-49ec-a6bd-5c3de741553d} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 562, line 563) (in query: SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL);) 2025.11.13 09:12:28.943182 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.958116 [ 18771 ] {a4a1ad03-d3d8-46e4-83b4-1483854a2ff4} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 563, line 564) (in query: SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL);) 2025.11.13 09:12:28.960270 [ 10181 ] {205febb4-8f92-4506-b604-fc0f275e47d8} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1015, line 1017) (in query: SELECT percentRank(NULL, NULL, NULL);) 2025.11.13 09:12:28.972055 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:28.981809 [ 10181 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:12:29.023405 [ 18771 ] {d84160d2-f1cb-48d5-aabd-1ca4e9879784} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 564, line 565) (in query: SELECT firstValueRespectNulls(NULL, NULL, NULL);) 2025.11.13 09:12:29.039296 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.039849 [ 10181 ] {bce658c8-df31-46fb-afc8-d58a78594b90} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1016, line 1018) (in query: SELECT percent_rank(NULL, NULL, NULL);) 2025.11.13 09:12:29.057492 [ 10181 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:12:29.073274 [ 10181 ] {42efefb3-47b3-4730-aea0-75da1944e7b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1017, line 1019) (in query: SELECT pi(NULL, NULL, NULL);) 2025.11.13 09:12:29.081831 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.102243 [ 10181 ] {6a64fed1-d194-44c4-8ff6-dcf6794ce1dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1018, line 1020) (in query: SELECT plus(NULL, NULL, NULL);) 2025.11.13 09:12:29.108635 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.134235 [ 10181 ] {3f0ba9a9-409e-4d7b-b96c-c8a562934176} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1019, line 1021) (in query: SELECT pmod(NULL, NULL, NULL);) 2025.11.13 09:12:29.141615 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.216097 [ 18771 ] {384ba498-097a-4bb1-8e93-f09b7f26f80e} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 566, line 567) (in query: SELECT first_value_respect_nulls(NULL, NULL, NULL);) 2025.11.13 09:12:29.233876 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.256917 [ 10181 ] {e7445e51-0ecd-4f2f-ad7d-70707357f046} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1022, line 1024) (in query: SELECT polygonAreaCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:29.259782 [ 18771 ] {9ad924f6-8106-47f4-903b-653bd2f73243} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 567, line 568) (in query: SELECT flameGraph(NULL, NULL, NULL);) 2025.11.13 09:12:29.263397 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.277263 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:29.283928 [ 10181 ] {a9b5809f-497b-4807-a326-59d475e0ca7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1023, line 1025) (in query: SELECT polygonAreaSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:29.292139 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.293783 [ 18771 ] {f4060809-d418-470b-85a2-f6325640da0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 568, line 569) (in query: SELECT flatten(NULL, NULL, NULL);) 2025.11.13 09:12:29.307349 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.320475 [ 10181 ] {ecce8a1f-5730-43f6-b3f4-1928d5fb0204} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1024, line 1026) (in query: SELECT polygonConvexHullCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:29.326088 [ 18771 ] {2f792a66-99bf-4469-84ac-b13c3d2cb48a} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 569, line 570) (in query: SELECT flattenTuple(NULL, NULL, NULL);) 2025.11.13 09:12:29.334098 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.361607 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.394526 [ 19606 ] {2a00925c-20b8-4252-8a61-a23312cb2510} PostgreSQLConnectionPool: Connection error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? 2025.11.13 09:12:29.396177 [ 19606 ] {2a00925c-20b8-4252-8a61-a23312cb2510} PostgreSQLConnectionPool: Connection error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? 2025.11.13 09:12:29.406450 [ 10181 ] {a23e012a-d3fc-4fbb-afc2-d74d128052d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1025, line 1027) (in query: SELECT polygonPerimeterCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:29.422495 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.441449 [ 10181 ] {da5479e4-0d26-40a1-b4f7-32eff1313e30} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1026, line 1028) (in query: SELECT polygonPerimeterSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:29.454980 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.470741 [ 10181 ] {abe5c742-a291-49dd-88a5-30b7646e6e91} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1027, line 1029) (in query: SELECT polygonsDistanceCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:29.477893 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.495804 [ 10181 ] {14cc3ea3-9861-4179-914e-f1a21a53f485} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1028, line 1030) (in query: SELECT polygonsDistanceSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:29.507848 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.531256 [ 10181 ] {32a58a5b-8eaa-4e18-9b0d-18e292235778} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1029, line 1031) (in query: SELECT polygonsEqualsCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:29.538161 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.562381 [ 10181 ] {ef8edd0b-0378-474e-a0ca-411891e64354} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1030, line 1032) (in query: SELECT polygonsIntersectionCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:29.563349 [ 18771 ] {4f68e90c-5c38-43e7-8992-1cab22f2ee5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 574, line 575) (in query: SELECT formatQuery(NULL, NULL, NULL);) 2025.11.13 09:12:29.570417 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.587983 [ 10181 ] {c183a105-5fe3-4a49-8a17-0c3ec61fb34b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1031, line 1033) (in query: SELECT polygonsIntersectionSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:29.597239 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.613858 [ 10181 ] {678f30b0-f9ca-4c1a-9b9d-2a2fdb284764} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1032, line 1034) (in query: SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:29.619479 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.635794 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.682452 [ 18771 ] {11573b97-6837-4d8f-a102-dd41dc12c16e} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 575, line 576) (in query: SELECT formatQueryOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:29.687981 [ 10181 ] {33e45eeb-c7f0-4c04-ab30-5d565b5eba8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1033, line 1035) (in query: SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:29.690716 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.693745 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.710722 [ 18771 ] {c741f7ec-250c-47fe-8934-d292c379b73c} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 576, line 577) (in query: SELECT formatQuerySingleLine(NULL, NULL, NULL);) 2025.11.13 09:12:29.712253 [ 10181 ] {5a4df6b2-f91b-43c3-a08b-cdc4cad11e70} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1034, line 1036) (in query: SELECT polygonsUnionCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:29.723144 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.724552 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.742374 [ 18771 ] {cd531101-8a5f-4887-9a65-b6f5d0414ac5} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 577, line 578) (in query: SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:29.754664 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.781195 [ 18771 ] {b9b0808b-364d-448e-9a0a-b07a74965546} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 578, line 579) (in query: SELECT formatReadableDecimalSize(NULL, NULL, NULL);) 2025.11.13 09:12:29.795996 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.813373 [ 18771 ] {04382dc0-e9c1-4a68-a9ec-8f52ca4bc1f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 579, line 580) (in query: SELECT formatReadableQuantity(NULL, NULL, NULL);) 2025.11.13 09:12:29.827401 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.831678 [ 10181 ] {464fdec5-7fcc-4ca3-98ef-8bdd7b8c7c9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1035, line 1037) (in query: SELECT polygonsUnionSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:29.844287 [ 18771 ] {61bd2331-a2b7-4ca6-9bbe-753d3dee19c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 580, line 581) (in query: SELECT formatReadableSize(NULL, NULL, NULL);) 2025.11.13 09:12:29.858688 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.858688 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.886158 [ 10181 ] {a7c810ff-fdda-4470-8f5e-a31c4b583a2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1036, line 1038) (in query: SELECT polygonsWithinCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:29.895329 [ 19606 ] {2a00925c-20b8-4252-8a61-a23312cb2510} executeQuery: Code: 614. DB::Exception: Try 2. Connection to `127.121.0.1:5432` failed with error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? . (POSTGRESQL_CONNECTION_FAILURE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53304) (comment: 02888_system_tables_with_inaccessible_table_function.sql) (query 25, line 43) (in query: SELECT count() FROM test_0kpn03c9.tablefunc01), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x00000000266f091f 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x000000002d82a73f 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:215: DB::StoragePostgreSQL::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003888044b 5. ./src/Storages/StorageTableFunction.h:101: DB::StorageTableFunctionProxy::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000002d192afc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:29.896213 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.898899 [ 19606 ] {} TCPHandler: Code: 614. DB::Exception: Try 2. Connection to `127.121.0.1:5432` failed with error: connection to server at "127.121.0.1", port 5432 failed: Connection refused Is the server running on that host and accepting TCP/IP connections? . (POSTGRESQL_CONNECTION_FAILURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x00000000266f091f 3. ./build_docker/./src/Core/PostgreSQL/PoolWithFailover.cpp:222: postgres::PoolWithFailover::get() @ 0x000000002d82a73f 4. ./build_docker/./src/Storages/StoragePostgreSQL.cpp:215: DB::StoragePostgreSQL::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003888044b 5. ./src/Storages/StorageTableFunction.h:101: DB::StorageTableFunctionProxy::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000002d192afc 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:29.921216 [ 18771 ] {bcce60e5-70a8-4965-8c77-70e88a515570} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 582, line 583) (in query: SELECT formatRow(NULL, NULL, NULL);) 2025.11.13 09:12:29.929867 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:29.935039 [ 10181 ] {e8a2e37d-4352-48be-8d5f-bf64979bcae2} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1037, line 1039) (in query: SELECT polygonsWithinSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:29.942601 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:29.950823 [ 18771 ] {e835490e-1c82-4488-9668-16344c582141} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 583, line 584) (in query: SELECT formatRowNoNewline(NULL, NULL, NULL);) 2025.11.13 09:12:29.961413 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:29.980706 [ 18771 ] {4c6ef00f-aab8-4936-92b3-8641db1ac39e} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 584, line 585) (in query: SELECT fragment(NULL, NULL, NULL);) 2025.11.13 09:12:29.990427 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.009795 [ 18771 ] {67437e8f-f7df-4e16-94d0-5eba1cd9fbc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 585, line 586) (in query: SELECT fromDaysSinceYearZero(NULL, NULL, NULL);) 2025.11.13 09:12:30.016456 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.047155 [ 18771 ] {272df5bd-c890-4727-851d-197a5461692d} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 586, line 587) (in query: SELECT fromDaysSinceYearZero32(NULL, NULL, NULL);) 2025.11.13 09:12:30.051950 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.174738 [ 18771 ] {777ff8c2-d78d-4f79-9bfa-ef9c31075fba} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 587, line 588) (in query: SELECT fromModifiedJulianDay(NULL, NULL, NULL);) 2025.11.13 09:12:30.179902 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.202526 [ 18771 ] {c2a09134-58bd-4bc0-b530-830e33d4564f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 588, line 589) (in query: SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:30.216674 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.232016 [ 18771 ] {f1ff3bb0-7a35-487c-9d2b-dc7efccc42d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 589, line 590) (in query: SELECT fromUTCTimestamp(NULL, NULL, NULL);) 2025.11.13 09:12:30.244286 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.355105 [ 10181 ] {28a54d36-0ac9-4ebd-9547-55afce760449} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1044, line 1046) (in query: SELECT positiveModulo(NULL, NULL, NULL);) 2025.11.13 09:12:30.361866 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.407589 [ 10181 ] {347907c7-570f-418e-8cde-0f2ae8021c40} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1045, line 1047) (in query: SELECT positive_modulo(NULL, NULL, NULL);) 2025.11.13 09:12:30.413931 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.436889 [ 10181 ] {f0479ac7-3bb8-4bdd-85b5-8958d9062c4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1046, line 1048) (in query: SELECT pow(NULL, NULL, NULL);) 2025.11.13 09:12:30.450051 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.468580 [ 10181 ] {d46945c7-cc26-4e18-a179-6ade85d5321d} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1047, line 1049) (in query: SELECT power(NULL, NULL, NULL);) 2025.11.13 09:12:30.476385 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.649262 [ 10181 ] {8be9eba3-9556-41fb-bc91-c032bfd2da76} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1049, line 1051) (in query: SELECT proportionsZTest(NULL, NULL, NULL);) 2025.11.13 09:12:30.663709 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.687453 [ 18771 ] {9dc73f03-2205-4ed4-8116-ba5a7e6b8241} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 596, line 597) (in query: SELECT from_utc_timestamp(NULL, NULL, NULL);) 2025.11.13 09:12:30.691948 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.701358 [ 10181 ] {ff171e4d-840d-4197-bca2-d597e4254e6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1050, line 1052) (in query: SELECT protocol(NULL, NULL, NULL);) 2025.11.13 09:12:30.706839 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.730389 [ 10181 ] {dc7071a2-291a-4289-b390-36a29df5c951} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1051, line 1053) (in query: SELECT punycodeDecode(NULL, NULL, NULL);) 2025.11.13 09:12:30.741351 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.750203 [ 18771 ] {d4266de9-212c-4347-ab0b-c04cd2ce936c} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 597, line 598) (in query: SELECT fullHostName(NULL, NULL, NULL);) 2025.11.13 09:12:30.756965 [ 10181 ] {f9a197ce-eda0-4440-8628-c468c44a5da7} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1052, line 1054) (in query: SELECT punycodeEncode(NULL, NULL, NULL);) 2025.11.13 09:12:30.762057 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.851741 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:30.875161 [ 18771 ] {1456f8be-6b4d-44b0-b068-9a64f05435f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 598, line 599) (in query: SELECT fuzzBits(NULL, NULL, NULL);) 2025.11.13 09:12:30.888139 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.054121 [ 18771 ] {8104b7df-3f3b-4c71-8e95-bc05f8d9ec5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 600, line 601) (in query: SELECT gcd(NULL, NULL, NULL);) 2025.11.13 09:12:31.061966 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.083689 [ 18771 ] {c20c2beb-8c07-4a26-aa03-38c048953701} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 601, line 602) (in query: SELECT generateRandomStructure(NULL, NULL, NULL);) 2025.11.13 09:12:31.093898 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.113361 [ 18771 ] {1094b67a-979d-47b7-bbde-8fb80d6e25e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 3, should be 1: In scope SELECT generateSerialID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 602, line 603) (in query: SELECT generateSerialID(NULL, NULL, NULL);) 2025.11.13 09:12:31.117940 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 3, should be 1: In scope SELECT generateSerialID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.141411 [ 18771 ] {fa79dcea-67de-4e22-a255-258f8ca271dd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 603, line 604) (in query: SELECT generateSnowflakeID(NULL, NULL, NULL);) 2025.11.13 09:12:31.154955 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.415512 [ 18771 ] {bb156258-059b-469e-8957-c8353e607500} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 605, line 606) (in query: SELECT generateUUIDv4(NULL, NULL, NULL);) 2025.11.13 09:12:31.421731 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.450780 [ 18771 ] {cd1d863f-debd-4e2a-8217-5063eba7fdfd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 606, line 607) (in query: SELECT generateUUIDv7(NULL, NULL, NULL);) 2025.11.13 09:12:31.470789 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.498344 [ 18771 ] {8d6ef3ca-ebeb-4a72-a43b-2121618b8503} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 607, line 608) (in query: SELECT geoDistance(NULL, NULL, NULL);) 2025.11.13 09:12:31.521891 [ 16712 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003a3dfd6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003d179be4 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1795: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003d15fa02 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:928: Coordination::ZooKeeper::receiveEvent() @ 0x000000003d15c45b 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:875: Coordination::ZooKeeper::receiveThread() @ 0x000000003d15aaf9 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003d175e4f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:31.522662 [ 3467 ] {} test_15.partitioned_table (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:12:31.522800 [ 3462 ] {} test_15.data_rep_02228 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:12:31.522912 [ 3458 ] {} test_1.t_mutations_nondeterministic (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:12:31.523043 [ 3465 ] {} test_9.test_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:12:31.562439 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.658736 [ 18771 ] {b0a3e9de-c221-4bd2-983d-580bf04e0146} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 609, line 610) (in query: SELECT geoToS2(NULL, NULL, NULL);) 2025.11.13 09:12:31.666340 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.694452 [ 18771 ] {cd763513-c642-4c00-911e-477071e99be3} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 610, line 611) (in query: SELECT geohashDecode(NULL, NULL, NULL);) 2025.11.13 09:12:31.703707 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.794874 [ 18771 ] {4570afc8-968c-41e1-8b17-38a4282fbddd} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 612, line 613) (in query: SELECT geohashesInBox(NULL, NULL, NULL);) 2025.11.13 09:12:31.801839 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.827184 [ 18771 ] {c4a3d52e-669c-482b-9553-3f59ea6e3152} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 613, line 614) (in query: SELECT getClientHTTPHeader(NULL, NULL, NULL);) 2025.11.13 09:12:31.834275 [ 18771 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.11.13 09:12:31.862733 [ 18771 ] {9f078b5a-7b01-496f-8794-1354f35ef8d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 614, line 615) (in query: SELECT getMacro(NULL, NULL, NULL);) 2025.11.13 09:12:31.876514 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.884719 [ 17752 ] {4857129c-d576-4eb3-8b39-a00e92fef775} DynamicQueryHandler: Code: 69. DB::Exception: Chunk size exceeded the limit (max size: 107374182400). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ad3644a 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:36: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x000000003af3afbf 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x000000003af3b5fd 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./build_docker/./src/IO/PeekableReadBuffer.cpp:179: DB::PeekableReadBuffer::nextImpl() @ 0x000000001f9d80e2 8. DB::ReadBuffer::next() @ 0x0000000008ef7cef 9. ./src/IO/ReadBuffer.h:96: DB::HTMLForm::MultipartReadBuffer::skipToNextBoundary() @ 0x000000003af2b65e 10. ./build_docker/./src/Server/HTTP/HTMLForm.cpp:197: DB::HTMLForm::readMultipart(DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x000000003af29821 11. ./build_docker/./src/Server/HTTP/HTMLForm.cpp:110: DB::HTMLForm::load(Poco::Net::HTTPRequest const&, DB::ReadBuffer&, DB::HTMLForm::PartHandler&) @ 0x000000003af26c60 12. ./build_docker/./src/Server/HTTPHandler.cpp:836: DB::DynamicQueryHandler::getQuery(DB::HTTPServerRequest&, DB::HTMLForm&, std::shared_ptr) @ 0x000000003acf370b 13. ./build_docker/./src/Server/HTTPHandler.cpp:471: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde5df 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:31.905526 [ 18771 ] {6fe1d497-6545-4ec4-945b-759841bb98f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 615, line 616) (in query: SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL);) 2025.11.13 09:12:31.909879 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:31.969986 [ 18771 ] {d3a56013-a098-4fbc-b222-a40a1c0f37b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 616, line 617) (in query: SELECT getOSKernelVersion(NULL, NULL, NULL);) 2025.11.13 09:12:31.985931 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.003539 [ 18771 ] {200fa725-e690-411b-8a7e-8d7fe609cd17} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 617, line 618) (in query: SELECT getServerPort(NULL, NULL, NULL);) 2025.11.13 09:12:32.017151 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.127621 [ 18771 ] {b4542697-4603-4871-a153-3744203cdfad} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 618, line 619) (in query: SELECT getSetting(NULL, NULL, NULL);) 2025.11.13 09:12:32.133832 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.245397 [ 18771 ] {4c17dd36-1a61-4534-b8b2-04695dce1ed3} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 619, line 620) (in query: SELECT getSettingOrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:32.251362 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.271755 [ 10181 ] {b24ae874-549e-406e-b281-ca35c2fec61e} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1071, line 1073) (in query: SELECT quantiles(NULL, NULL, NULL);) 2025.11.13 09:12:32.275323 [ 18771 ] {51d444ef-7446-4b2c-895e-c72fa2d2d981} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 620, line 621) (in query: SELECT getSizeOfEnumType(NULL, NULL, NULL);) 2025.11.13 09:12:32.276863 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:32.288178 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.298735 [ 10181 ] {2c491aef-2d54-470c-a75b-e3b72ee70142} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1072, line 1074) (in query: SELECT quantilesBFloat16(NULL, NULL, NULL);) 2025.11.13 09:12:32.303675 [ 18771 ] {2fef50da-e643-4272-b112-5f4b402da974} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 621, line 622) (in query: SELECT getSubcolumn(NULL, NULL, NULL);) 2025.11.13 09:12:32.303729 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:32.314073 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.337360 [ 18771 ] {b7d05d8e-c67d-41bd-9ac8-8f1f584d9419} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 622, line 623) (in query: SELECT getTypeSerializationStreams(NULL, NULL, NULL);) 2025.11.13 09:12:32.342422 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.367499 [ 18771 ] {d28f6e85-2a00-47e6-9b71-a684683ccbd4} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 623, line 624) (in query: SELECT globalIn(NULL, NULL, NULL);) 2025.11.13 09:12:32.376056 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.376574 [ 16196 ] {4ff60d02-c89f-49f3-81c6-2605c2b73674} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_5/log/query-0000000064/active/s1|r1. (KEEPER_EXCEPTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37360) (comment: 02811_read_in_order_and_array_join_bug.sql) (query 3, line 3) (in query: CREATE TABLE test_array_joins (`id` UInt64 DEFAULT rowNumberInAllBlocks() + 1, `arr_1` Array(String), `arr_2` Array(String), `arr_3` Array(String), `arr_4` Array(String)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 9659, min_bytes_for_wide_part = 622686559, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 341546838, compact_parts_max_granules_to_buffer = 227, compact_parts_merge_max_bytes_to_prefetch_part = 1461703, merge_max_block_size = 3454, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 620916, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 24941469, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 45, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 11711, primary_key_compress_block_size = 62106, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000f1265ec 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:418: zkutil::ZooKeeper::tryCreate(String const&, String const&, int, String&) @ 0x000000003cffc223 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:426: zkutil::ZooKeeper::tryCreate(String const&, String const&, int) @ 0x000000003cffc522 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:600: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a87f3a 7. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:32.387882 [ 16196 ] {} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_5/log/query-0000000064/active/s1|r1. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000f1265ec 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:418: zkutil::ZooKeeper::tryCreate(String const&, String const&, int, String&) @ 0x000000003cffc223 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:426: zkutil::ZooKeeper::tryCreate(String const&, String const&, int) @ 0x000000003cffc522 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:600: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a87f3a 7. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:12:32.476163 [ 18771 ] {dbe325c6-a9d3-4675-949f-dde65c425240} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 624, line 625) (in query: SELECT globalInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:32.481431 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.509338 [ 18771 ] {7b476058-1f1f-4285-824e-f9c94660267c} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 625, line 626) (in query: SELECT globalNotIn(NULL, NULL, NULL);) 2025.11.13 09:12:32.512132 [ 10181 ] {a30ca3d2-17eb-4186-aa20-fb108159a197} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1074, line 1076) (in query: SELECT quantilesDD(NULL, NULL, NULL);) 2025.11.13 09:12:32.514829 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.524870 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:32.531014 [ 17752 ] {4857129c-d576-4eb3-8b39-a00e92fef775} void DB::drainRequestIfNeeded(HTTPServerRequest &, HTTPServerResponse &): Cannot read remaining request body during exception handling. Set keep alive to false on the response.: Code: 408. DB::Exception: Unexpected data instead of HTTP chunk header. (BAD_REQUEST_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:25: DB::HTTPChunkedReadBuffer::readChunkHeader() @ 0x000000003af3b36e 5. ./build_docker/./src/IO/HTTPChunkedReadBuffer.cpp:63: DB::HTTPChunkedReadBuffer::nextImpl() @ 0x000000003af3b5fd 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::drainRequestIfNeeded(DB::HTTPServerRequest&, DB::HTTPServerResponse&) @ 0x000000003af5a431 8. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:272: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000003af4850f 9. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace747b 10. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:32.539202 [ 18771 ] {30c94449-7a20-4174-82ba-90b0e80df18f} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 626, line 627) (in query: SELECT globalNotInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:32.541160 [ 10181 ] {6aa29501-bd5f-4b88-a40d-69faf4c3dcf6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1075, line 1077) (in query: SELECT quantilesDeterministic(NULL, NULL, NULL);) 2025.11.13 09:12:32.544539 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.545871 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:32.575187 [ 10181 ] {45bdc795-8c37-4334-a075-65a6665ba631} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1076, line 1078) (in query: SELECT quantilesExact(NULL, NULL, NULL);) 2025.11.13 09:12:32.588187 [ 18771 ] {d79a8837-da58-4d6f-aba6-3cd7d22c490f} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 627, line 628) (in query: SELECT globalNotNullIn(NULL, NULL, NULL);) 2025.11.13 09:12:32.795469 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:32.817377 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.817514 [ 10181 ] {60060ae3-dad9-4bf3-a072-c5cd9c8ad4ce} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1077, line 1079) (in query: SELECT quantilesExactExclusive(NULL, NULL, NULL);) 2025.11.13 09:12:32.826002 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:32.857790 [ 10181 ] {78dc7ee9-fe5a-4ce0-8fde-893d4d7544a8} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1078, line 1080) (in query: SELECT quantilesExactHigh(NULL, NULL, NULL);) 2025.11.13 09:12:32.863583 [ 18771 ] {ffff8e16-2f39-4de6-bb49-0a8ed40cca45} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 628, line 629) (in query: SELECT globalNotNullInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:32.881050 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.898410 [ 18771 ] {35975983-e0f5-44c1-8394-b4b0eab275f7} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 629, line 630) (in query: SELECT globalNullIn(NULL, NULL, NULL);) 2025.11.13 09:12:32.922562 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.943105 [ 18771 ] {efa8a25b-1f73-4d22-9236-49cbd53e7e88} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 630, line 631) (in query: SELECT globalNullInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:32.950222 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.963319 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:32.970578 [ 18771 ] {e75291ae-13b4-4507-a7fe-1fa161f427f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 631, line 632) (in query: SELECT globalVariable(NULL, NULL, NULL);) 2025.11.13 09:12:32.980682 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:32.984399 [ 10181 ] {60aa455e-d4e4-4b07-bd2c-6d1d769691d4} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1079, line 1081) (in query: SELECT quantilesExactInclusive(NULL, NULL, NULL);) 2025.11.13 09:12:32.996465 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:33.013328 [ 10181 ] {d81a4c46-13eb-4529-a21e-88f0e4a7c213} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1080, line 1082) (in query: SELECT quantilesExactLow(NULL, NULL, NULL);) 2025.11.13 09:12:33.030188 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:33.041828 [ 17752 ] {4857129c-d576-4eb3-8b39-a00e92fef775} bool DB::WriteBufferFromHTTPServerResponse::cancelWithException(HTTPServerRequest &, int, const std::string &, WriteBuffer *): Failed to send exception to the response write buffer.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:36048). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:116: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x000000001fcafaa9 4. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:70: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*, DB::Progress::DisplayMode) @ 0x000000003af45552 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:79: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x000000003af45d37 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:214: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x000000003af47873 7. ./build_docker/./src/IO/WriteBuffer.cpp:95: DB::WriteBuffer::finalize() @ 0x000000001f9df056 8. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:284: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000003af48744 9. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace747b 10. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:33.050281 [ 10181 ] {7d243579-2b3e-4e34-ac1d-3ff8f1ec07cc} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1081, line 1083) (in query: SELECT quantilesExactWeighted(NULL, NULL, NULL);) 2025.11.13 09:12:33.065754 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:33.094587 [ 18771 ] {4eeb4a2b-5265-48c7-bda6-38c47f02c5ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 632, line 633) (in query: SELECT greatCircleAngle(NULL, NULL, NULL);) 2025.11.13 09:12:33.102537 [ 10181 ] {a1b5c667-f633-4734-9502-d6971350b9c1} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1082, line 1084) (in query: SELECT quantilesExactWeightedInterpolated(NULL, NULL, NULL);) 2025.11.13 09:12:33.108202 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.112274 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:33.127583 [ 10181 ] {7dd20b08-525c-490e-9703-bdcd5afad9f1} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1083, line 1085) (in query: SELECT quantilesGK(NULL, NULL, NULL);) 2025.11.13 09:12:33.137977 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:33.177514 [ 10181 ] {728787b5-64e4-40a2-b718-1a9ca0dd5db6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1084, line 1086) (in query: SELECT quantilesInterpolatedWeighted(NULL, NULL, NULL);) 2025.11.13 09:12:33.185536 [ 18771 ] {646365cf-9bca-4c1d-be55-2c21140237a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 633, line 634) (in query: SELECT greatCircleDistance(NULL, NULL, NULL);) 2025.11.13 09:12:33.198655 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.261141 [ 18771 ] {0bea7032-3810-4fa6-92a4-785a9060b9f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 634, line 635) (in query: SELECT greater(NULL, NULL, NULL);) 2025.11.13 09:12:33.274036 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.278157 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:33.292471 [ 18771 ] {02ef7a0b-db76-41d2-a10a-4493b5695f42} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 635, line 636) (in query: SELECT greaterOrEquals(NULL, NULL, NULL);) 2025.11.13 09:12:33.298403 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.301792 [ 10181 ] {00056a28-1b17-419e-a2b6-8686799503fa} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1085, line 1087) (in query: SELECT quantilesTDigest(NULL, NULL, NULL);) 2025.11.13 09:12:33.311893 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:33.326748 [ 10181 ] {f121736f-3a86-46db-8474-9f2534525280} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1086, line 1088) (in query: SELECT quantilesTDigestWeighted(NULL, NULL, NULL);) 2025.11.13 09:12:33.337693 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:33.394548 [ 10181 ] {acdb4486-606c-4e19-8177-2e5998022c90} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1087, line 1089) (in query: SELECT quantilesTiming(NULL, NULL, NULL);) 2025.11.13 09:12:33.423491 [ 4454 ] {} DDLWorker(test_11): Replica seems to be lost: our_log_ptr=63, max_log_ptr=63, local_digest=15354366268113416420, zk_digest=5590053988479068626 2025.11.13 09:12:33.423860 [ 4454 ] {} DatabaseReplicated (test_11): Will recover replica with staled log pointer 63 from log pointer 63 2025.11.13 09:12:33.430450 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:33.433717 [ 17251 ] {} DDLWorker(test_pcypyn69): Replica seems to be lost: our_log_ptr=3, max_log_ptr=3, local_digest=3276277671756534747, zk_digest=0 2025.11.13 09:12:33.433825 [ 17251 ] {} DatabaseReplicated (test_pcypyn69): Will recover replica with staled log pointer 3 from log pointer 3 2025.11.13 09:12:33.434977 [ 4454 ] {} DatabaseReplicated (test_11): Will recreate 1 broken tables to recover replica 2025.11.13 09:12:33.437818 [ 4454 ] {} Context: Server has databases (for example `test_11_broken_tables`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.11.13 09:12:33.444890 [ 17251 ] {} DatabaseReplicated (test_pcypyn69): Will recreate 1 broken tables to recover replica 2025.11.13 09:12:33.453537 [ 10181 ] {1e8c7619-1ffa-4e00-8d45-a0f7825cc67e} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1088, line 1090) (in query: SELECT quantilesTimingWeighted(NULL, NULL, NULL);) 2025.11.13 09:12:33.467340 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:33.484180 [ 17251 ] {} DatabaseReplicated (test_pcypyn69): Cleaned 1 outdated objects: dropped 0 dictionaries and 1 tables, moved 0 tables 2025.11.13 09:12:33.489415 [ 10181 ] {d88c0c86-51d3-43f3-9e29-22da23d63232} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1089, line 1091) (in query: SELECT queryID(NULL, NULL, NULL);) 2025.11.13 09:12:33.492743 [ 16199 ] {22693963-24fd-4b7f-a2f0-9899bef2cd45} executeQuery: Code: 497. DB::Exception: user03631_test_kr831c2v_27565: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_kr831c2v.test_table. (ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37372) (comment: 03631_buffer_access_check.sh) (query 1, line 1) (in query: SELECT * FROM test_kr831c2v.test_buffer), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e3bb90a 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e3b7d6f 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002e3b625a 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002e31b27b 7. ./src/Access/ContextAccess.h:259: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x0000000031869a09 8. ./build_docker/./src/Interpreters/Context.cpp:1758: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000317cce23 9. ./build_docker/./src/Storages/StorageBuffer.cpp:294: DB::StorageBuffer::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038f94da6 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 12. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 13. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:33.496881 [ 4454 ] {} DatabaseReplicated (test_11): Cleaned 1 outdated objects: dropped 0 dictionaries and 0 tables, moved 1 tables 2025.11.13 09:12:33.501532 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.510033 [ 16199 ] {} TCPHandler: Code: 497. DB::Exception: user03631_test_kr831c2v_27565: Not enough privileges. To execute this query, it's necessary to have the grant SELECT(s) ON test_kr831c2v.test_table. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e3bb90a 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&, std::vector> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e3b7d6f 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x000000002e3b625a 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000002e31b27b 7. ./src/Access/ContextAccess.h:259: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x0000000031869a09 8. ./build_docker/./src/Interpreters/Context.cpp:1758: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000317cce23 9. ./build_docker/./src/Storages/StorageBuffer.cpp:294: DB::StorageBuffer::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038f94da6 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 12. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 13. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:33.520992 [ 10181 ] {c10a0f9a-4e16-4d49-9888-d734b0ccdb8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1090, line 1092) (in query: SELECT queryString(NULL, NULL, NULL);) 2025.11.13 09:12:33.531575 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.547710 [ 10181 ] {1f059925-f66f-4c54-88ac-917fb11910b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1091, line 1093) (in query: SELECT queryStringAndFragment(NULL, NULL, NULL);) 2025.11.13 09:12:33.553889 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.594102 [ 10181 ] {8afb8bec-068e-4429-9879-60650bed6448} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1092, line 1094) (in query: SELECT query_id(NULL, NULL, NULL);) 2025.11.13 09:12:33.600784 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.623223 [ 10181 ] {dba334f9-e906-4e63-a2ee-6078d42884c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1093, line 1095) (in query: SELECT radians(NULL, NULL, NULL);) 2025.11.13 09:12:33.628823 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.638867 [ 16223 ] {5daff7b8-5045-4d70-b39d-a6e61249940a} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss. (KEEPER_EXCEPTION) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00650_array_enumerate_uniq_with_tuples.sql) (in query: /* ddl_entry=query-0000000003 */ DROP TABLE test_pcypyn69.tab_00650 SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, char const*&&) @ 0x000000003cfe375b 4. ./build_docker/./src/Common/ZooKeeper/KeeperException.cpp:35: Coordination::Exception::Exception(Coordination::Error) @ 0x000000003cfe3561 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1621: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003d00c193 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:811: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003d00be59 7. ./build_docker/./src/Interpreters/DDLTask.cpp:599: DB::ZooKeeperMetadataTransaction::commit() @ 0x0000000031a5e27f 8. ./build_docker/./src/Databases/DatabaseAtomic.cpp:184: DB::DatabaseAtomic::dropTableImpl(std::shared_ptr, String const&, bool) @ 0x000000002f8b1942 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1753: DB::DatabaseReplicated::dropTable(std::shared_ptr, String const&, bool) @ 0x000000002fa17121 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:309: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6b8f7 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 18. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 19. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 21. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 22. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 23. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:12:33.645013 [ 16223 ] {5daff7b8-5045-4d70-b39d-a6e61249940a} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss. (KEEPER_EXCEPTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37292) (comment: 00650_array_enumerate_uniq_with_tuples.sql) (query 10, line 11) (in query: drop table tab_00650;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, char const*&&) @ 0x000000003cfe375b 4. ./build_docker/./src/Common/ZooKeeper/KeeperException.cpp:35: Coordination::Exception::Exception(Coordination::Error) @ 0x000000003cfe3561 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1621: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003d00c193 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:811: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003d00be59 7. ./build_docker/./src/Interpreters/DDLTask.cpp:599: DB::ZooKeeperMetadataTransaction::commit() @ 0x0000000031a5e27f 8. ./build_docker/./src/Databases/DatabaseAtomic.cpp:184: DB::DatabaseAtomic::dropTableImpl(std::shared_ptr, String const&, bool) @ 0x000000002f8b1942 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1753: DB::DatabaseReplicated::dropTable(std::shared_ptr, String const&, bool) @ 0x000000002fa17121 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:309: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6b8f7 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 18. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 19. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 21. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 22. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 23. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:12:33.651051 [ 16223 ] {} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, char const*&&) @ 0x000000003cfe375b 4. ./build_docker/./src/Common/ZooKeeper/KeeperException.cpp:35: Coordination::Exception::Exception(Coordination::Error) @ 0x000000003cfe3561 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1621: zkutil::KeeperMultiException::check(Coordination::Error, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&) @ 0x000000003d00c193 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:811: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003d00be59 7. ./build_docker/./src/Interpreters/DDLTask.cpp:599: DB::ZooKeeperMetadataTransaction::commit() @ 0x0000000031a5e27f 8. ./build_docker/./src/Databases/DatabaseAtomic.cpp:184: DB::DatabaseAtomic::dropTableImpl(std::shared_ptr, String const&, bool) @ 0x000000002f8b1942 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1753: DB::DatabaseReplicated::dropTable(std::shared_ptr, String const&, bool) @ 0x000000002fa17121 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:309: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6b8f7 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 16. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 18. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 19. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 20. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 21. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 22. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 23. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:12:33.653129 [ 10181 ] {d4724b2e-dfb5-4ab6-970b-e21407845b33} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1094, line 1096) (in query: SELECT rand(NULL, NULL, NULL);) 2025.11.13 09:12:33.664916 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.681069 [ 10181 ] {df7af14a-2057-401f-96f6-6d3c2200ee4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1095, line 1097) (in query: SELECT rand32(NULL, NULL, NULL);) 2025.11.13 09:12:33.691849 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.750951 [ 10181 ] {a392c71f-d2b9-4731-a2f3-bd26b3f4141a} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1096, line 1098) (in query: SELECT rand64(NULL, NULL, NULL);) 2025.11.13 09:12:33.756249 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:33.783619 [ 2997 ] {cdce90d7-acab-4b0b-b454-bf56878e6f30} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50552) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_tg91tviv`.`test_parallel_replicas_automatic_count` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:12:33.836117 [ 2997 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:33.972640 [ 16196 ] {02784_automatic_parallel_replicas-test_tg91tviv_whole_table_1M_pure} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37408) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count SETTINGS use_query_condition_cache = 0 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:12:33.989094 [ 10181 ] {e203b8dd-38db-4c7d-8aad-9b14030fdd87} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1099, line 1101) (in query: SELECT randCanonical(NULL, NULL, NULL);) 2025.11.13 09:12:33.999506 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:34.017146 [ 16196 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:34.054313 [ 16231 ] {70255713-2e2b-4cf1-880e-8540ad54faf7} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00623_truncate_table.sql) (in query: /* ddl_entry=query-0000000064 */ CREATE MATERIALIZED VIEW test_11.truncate_test_materialized_view UUID 'd21fa714-d966-4214-994a-bed6386b80d0' TO INNER UUID '107a0b2c-1386-45e3-ad02-9b53b769d947' (`p` Date, `k` UInt64) ENGINE = MergeTree(p, k, 1) AS SELECT * FROM test_11.truncate_test_materialized_depend), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003d0a7a6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160d5e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1651: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000003d174cd4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1449: zkutil::ZooKeeper::asyncTryMultiNoThrow(std::span const, 18446744073709551615ul>) @ 0x000000003d02cd46 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1436: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000003cfffb09 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:807: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003d00bdcb 8. ./build_docker/./src/Interpreters/DDLTask.cpp:599: DB::ZooKeeperMetadataTransaction::commit() @ 0x0000000031a5e27f 9. ./build_docker/./src/Databases/DatabaseAtomic.cpp:371: DB::DatabaseAtomic::commitCreateTable(DB::ASTCreateQuery const&, std::shared_ptr const&, String const&, String const&, std::shared_ptr) @ 0x000000002f8b9540 10. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1855: DB::DatabaseReplicated::commitCreateTable(DB::ASTCreateQuery const&, std::shared_ptr const&, String const&, String const&, std::shared_ptr) @ 0x000000002fa1d14b 11. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:274: DB::DatabaseOnDisk::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002f912a05 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2009: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1a03c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:34.088310 [ 10181 ] {18de9523-b187-4433-991f-9ca109581d4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1101, line 1103) (in query: SELECT randConstant(NULL, NULL, NULL);) 2025.11.13 09:12:34.101991 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:34.115590 [ 16231 ] {70255713-2e2b-4cf1-880e-8540ad54faf7} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53486) (comment: 00623_truncate_table.sql) (query 16, line 18) (in query: CREATE MATERIALIZED VIEW truncate_test_materialized_view ENGINE = MergeTree(p, k, 1) AS SELECT * FROM truncate_test_materialized_depend;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003d0a7a6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160d5e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1651: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000003d174cd4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1449: zkutil::ZooKeeper::asyncTryMultiNoThrow(std::span const, 18446744073709551615ul>) @ 0x000000003d02cd46 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1436: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000003cfffb09 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:807: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003d00bdcb 8. ./build_docker/./src/Interpreters/DDLTask.cpp:599: DB::ZooKeeperMetadataTransaction::commit() @ 0x0000000031a5e27f 9. ./build_docker/./src/Databases/DatabaseAtomic.cpp:371: DB::DatabaseAtomic::commitCreateTable(DB::ASTCreateQuery const&, std::shared_ptr const&, String const&, String const&, std::shared_ptr) @ 0x000000002f8b9540 10. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1855: DB::DatabaseReplicated::commitCreateTable(DB::ASTCreateQuery const&, std::shared_ptr const&, String const&, String const&, std::shared_ptr) @ 0x000000002fa1d14b 11. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:274: DB::DatabaseOnDisk::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002f912a05 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2009: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1a03c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:34.139868 [ 16231 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003d0a7a6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160d5e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1651: Coordination::ZooKeeper::multi(std::span const, 18446744073709551615ul>, std::function) @ 0x000000003d174cd4 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1449: zkutil::ZooKeeper::asyncTryMultiNoThrow(std::span const, 18446744073709551615ul>) @ 0x000000003d02cd46 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1436: zkutil::ZooKeeper::multiImpl(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x000000003cfffb09 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:807: zkutil::ZooKeeper::multi(std::vector, std::allocator>> const&, bool) @ 0x000000003d00bdcb 8. ./build_docker/./src/Interpreters/DDLTask.cpp:599: DB::ZooKeeperMetadataTransaction::commit() @ 0x0000000031a5e27f 9. ./build_docker/./src/Databases/DatabaseAtomic.cpp:371: DB::DatabaseAtomic::commitCreateTable(DB::ASTCreateQuery const&, std::shared_ptr const&, String const&, String const&, std::shared_ptr) @ 0x000000002f8b9540 10. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1855: DB::DatabaseReplicated::commitCreateTable(DB::ASTCreateQuery const&, std::shared_ptr const&, String const&, String const&, std::shared_ptr) @ 0x000000002fa1d14b 11. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:274: DB::DatabaseOnDisk::createTable(std::shared_ptr, String const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002f912a05 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2009: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1a03c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 18. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 19. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 20. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:34.236929 [ 16230 ] {2b225851-bce1-4583-a7bf-cb159925c8ed} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:60382). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x000000003aea5649 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:34.543260 [ 10181 ] {fcecb04d-0b44-4e98-96aa-aec1001c179c} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1110, line 1112) (in query: SELECT randomFixedString(NULL, NULL, NULL);) 2025.11.13 09:12:34.559856 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:34.703657 [ 10181 ] {034e261b-5bad-475b-94d3-ada68a8a2f56} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1113, line 1115) (in query: SELECT randomStringUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:34.714201 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:34.897051 [ 10181 ] {4742bb6c-c2fb-43ca-9442-edcc9e9ccba7} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1115, line 1117) (in query: SELECT rank(NULL, NULL, NULL);) 2025.11.13 09:12:34.911526 [ 10181 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:12:34.922131 [ 6072 ] {07b51af9-aa78-4b7c-bc91-a7f2f641266a} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:59790). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:35.022109 [ 10181 ] {4730f1cf-18a8-4dbd-b63c-0ffadf211baf} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1117, line 1119) (in query: SELECT readWKTLineString(NULL, NULL, NULL);) 2025.11.13 09:12:35.033220 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.050578 [ 10181 ] {5c51f042-f6f4-47a6-9436-07c7b247573b} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1118, line 1120) (in query: SELECT readWKTMultiLineString(NULL, NULL, NULL);) 2025.11.13 09:12:35.104811 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.187167 [ 10181 ] {5aa1d03d-f1bc-45b9-bffd-f29066fcd647} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1119, line 1121) (in query: SELECT readWKTMultiPolygon(NULL, NULL, NULL);) 2025.11.13 09:12:35.197972 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.215012 [ 10181 ] {b974041e-ca83-4c67-ab7d-fadb7a77c12a} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1120, line 1122) (in query: SELECT readWKTPoint(NULL, NULL, NULL);) 2025.11.13 09:12:35.225308 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.241206 [ 10181 ] {caf4f9a0-ca39-4509-9a4a-1e7d74a46f1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1121, line 1123) (in query: SELECT readWKTPolygon(NULL, NULL, NULL);) 2025.11.13 09:12:35.245961 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.266934 [ 10181 ] {2003ddee-f31e-4eb9-a78f-ad5a1c170519} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1122, line 1124) (in query: SELECT readWKTRing(NULL, NULL, NULL);) 2025.11.13 09:12:35.271358 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.324423 [ 18771 ] {740a23f2-9efa-4f47-87c7-cf7c76af5731} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 655, line 656) (in query: SELECT h3CellAreaM2(NULL, NULL, NULL);) 2025.11.13 09:12:35.334539 [ 10181 ] {1a7be30a-ca27-448a-8593-e64cd5be83ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1124, line 1126) (in query: SELECT regexpQuoteMeta(NULL, NULL, NULL);) 2025.11.13 09:12:35.340954 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.340954 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.358924 [ 18771 ] {2a50af90-f54d-47fc-8222-d4bd846daba0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 656, line 657) (in query: SELECT h3CellAreaRads2(NULL, NULL, NULL);) 2025.11.13 09:12:35.363929 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.448948 [ 18771 ] {465aa911-64ec-45db-a96e-f83ddc6b983c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 657, line 658) (in query: SELECT h3Distance(NULL, NULL, NULL);) 2025.11.13 09:12:35.454292 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.482254 [ 18771 ] {49b11742-3557-4403-b754-daba52d51c62} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 658, line 659) (in query: SELECT h3EdgeAngle(NULL, NULL, NULL);) 2025.11.13 09:12:35.487411 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.546534 [ 18771 ] {7eb4cb39-6df4-4a2d-bfb8-3f0254b6cdb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 659, line 660) (in query: SELECT h3EdgeLengthKm(NULL, NULL, NULL);) 2025.11.13 09:12:35.563602 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.581744 [ 18771 ] {b3e6cb1b-85eb-4ad5-aa13-f2205298b64b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 660, line 661) (in query: SELECT h3EdgeLengthM(NULL, NULL, NULL);) 2025.11.13 09:12:35.587317 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.652427 [ 18771 ] {c20acc45-e53a-43b6-8ade-0357559d184b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 661, line 662) (in query: SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL);) 2025.11.13 09:12:35.657437 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.683446 [ 18771 ] {e5eeabe8-a6ef-48b6-a1e4-7c1e9ed4ab41} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 662, line 663) (in query: SELECT h3ExactEdgeLengthM(NULL, NULL, NULL);) 2025.11.13 09:12:35.690695 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.717190 [ 18771 ] {2caa4801-9f33-41c5-ba6c-dfa4ea5bd7fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 663, line 664) (in query: SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL);) 2025.11.13 09:12:35.724276 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.747997 [ 18771 ] {211c20a2-c943-49d1-9666-7fc0a04e376a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 664, line 665) (in query: SELECT h3GetBaseCell(NULL, NULL, NULL);) 2025.11.13 09:12:35.752630 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.782559 [ 18771 ] {99db5ae8-ad37-4b31-ae7c-f38ac44a249d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 665, line 666) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.11.13 09:12:35.802748 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.835428 [ 18771 ] {12e135ac-fb64-4534-8e3b-90a9bb8e7574} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 666, line 667) (in query: SELECT h3GetFaces(NULL, NULL, NULL);) 2025.11.13 09:12:35.839884 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.865939 [ 18771 ] {07e5e199-45fa-4050-ab57-558c46d3c879} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 667, line 668) (in query: SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.11.13 09:12:35.874098 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.898821 [ 10181 ] {aeb640e5-1a5b-4135-9eec-bec394dd6bf4} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1135, line 1137) (in query: SELECT reinterpret(NULL, NULL, NULL);) 2025.11.13 09:12:35.906324 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.928863 [ 10181 ] {3d5c0122-1579-4661-a195-4d929d6a3170} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1136, line 1138) (in query: SELECT reinterpretAsDate(NULL, NULL, NULL);) 2025.11.13 09:12:35.939320 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.961607 [ 10181 ] {ed2b3e3a-2eb2-4e3f-9a7f-114053805bd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1137, line 1139) (in query: SELECT reinterpretAsDateTime(NULL, NULL, NULL);) 2025.11.13 09:12:35.966512 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.975831 [ 18771 ] {7562e1c2-38ec-4745-9bc5-429bc54af55b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 668, line 669) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL);) 2025.11.13 09:12:35.987364 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:35.993395 [ 10181 ] {173cfafc-b091-4ef8-a5e9-2763362dbeb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1138, line 1140) (in query: SELECT reinterpretAsFixedString(NULL, NULL, NULL);) 2025.11.13 09:12:35.999310 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.012303 [ 18771 ] {9b2a467a-2987-4822-ad53-e42de07ea5da} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 669, line 670) (in query: SELECT h3GetPentagonIndexes(NULL, NULL, NULL);) 2025.11.13 09:12:36.017026 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.022014 [ 10181 ] {00704afc-414d-4559-babb-26aaa02c5201} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1139, line 1141) (in query: SELECT reinterpretAsFloat32(NULL, NULL, NULL);) 2025.11.13 09:12:36.027822 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.041027 [ 18771 ] {8368fba9-c42c-435f-b252-3e601690f634} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 670, line 671) (in query: SELECT h3GetRes0Indexes(NULL, NULL, NULL);) 2025.11.13 09:12:36.048416 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.049876 [ 10181 ] {415ca107-7309-4ecc-b01f-f6c753e744b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1140, line 1142) (in query: SELECT reinterpretAsFloat64(NULL, NULL, NULL);) 2025.11.13 09:12:36.054571 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.072415 [ 18771 ] {7f86cbf9-56c8-4ad6-988d-693df0325532} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 671, line 672) (in query: SELECT h3GetResolution(NULL, NULL, NULL);) 2025.11.13 09:12:36.076682 [ 10181 ] {e7839cdc-42ba-48d6-9838-130b3eb69297} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1141, line 1143) (in query: SELECT reinterpretAsInt128(NULL, NULL, NULL);) 2025.11.13 09:12:36.079386 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.081154 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.103531 [ 10181 ] {1d16346e-feb1-40c1-a4e6-73b9e689d45f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1142, line 1144) (in query: SELECT reinterpretAsInt16(NULL, NULL, NULL);) 2025.11.13 09:12:36.108116 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.129784 [ 10181 ] {e58be7e5-00a6-4510-b847-c2c361f98332} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1143, line 1145) (in query: SELECT reinterpretAsInt256(NULL, NULL, NULL);) 2025.11.13 09:12:36.134196 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.135431 [ 18771 ] {67292e1c-fa24-49df-a96f-d80edc121a4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 672, line 673) (in query: SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL);) 2025.11.13 09:12:36.140760 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.159216 [ 10181 ] {fe6f5d2a-81d0-41ad-a1c8-4ccee2a8df62} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1144, line 1146) (in query: SELECT reinterpretAsInt32(NULL, NULL, NULL);) 2025.11.13 09:12:36.165179 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.166576 [ 18771 ] {6b714407-0b2f-4bba-952a-c614f212b342} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 673, line 674) (in query: SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL);) 2025.11.13 09:12:36.171002 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.192754 [ 10181 ] {517f1696-6de2-4459-909f-cf8905284b1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1145, line 1147) (in query: SELECT reinterpretAsInt64(NULL, NULL, NULL);) 2025.11.13 09:12:36.199362 [ 18771 ] {90743634-73b4-4485-943d-b6868a3fa136} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 674, line 675) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL);) 2025.11.13 09:12:36.199765 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.207356 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.226701 [ 10181 ] {6471e5c9-7130-4d1b-8752-488a21313ac1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1146, line 1148) (in query: SELECT reinterpretAsInt8(NULL, NULL, NULL);) 2025.11.13 09:12:36.230332 [ 18771 ] {493b77a0-b41d-4ad7-82a0-631fa14c6d3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 675, line 676) (in query: SELECT h3HexAreaKm2(NULL, NULL, NULL);) 2025.11.13 09:12:36.232510 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.236965 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.254355 [ 10181 ] {34143540-2b99-4146-a7aa-c4fddd403769} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1147, line 1149) (in query: SELECT reinterpretAsString(NULL, NULL, NULL);) 2025.11.13 09:12:36.258161 [ 18771 ] {67cc76b0-17ae-43fc-8f1b-dc3387d83942} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 676, line 677) (in query: SELECT h3HexAreaM2(NULL, NULL, NULL);) 2025.11.13 09:12:36.260504 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.263446 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.376805 [ 10181 ] {6e4bd20d-d49a-460b-8320-dcb79d26296b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1148, line 1150) (in query: SELECT reinterpretAsUInt128(NULL, NULL, NULL);) 2025.11.13 09:12:36.377428 [ 18771 ] {1a583f2f-0082-485b-80ac-4a4b9d4624c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 677, line 678) (in query: SELECT h3HexRing(NULL, NULL, NULL);) 2025.11.13 09:12:36.382187 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.392322 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.404263 [ 10181 ] {0f30ef0e-49cc-43cc-a384-e31f5a8b411b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1149, line 1151) (in query: SELECT reinterpretAsUInt16(NULL, NULL, NULL);) 2025.11.13 09:12:36.408463 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.409689 [ 18771 ] {25428913-47eb-449c-8b09-df2ae89f727b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 678, line 679) (in query: SELECT h3IndexesAreNeighbors(NULL, NULL, NULL);) 2025.11.13 09:12:36.422795 [ 17376 ] {5922b1db-05c9-491b-a299-596b618d4c19} executeQuery: Code: 497. DB::Exception: user03631_test_kr831c2v_27565: Not enough privileges. To execute this query, it's necessary to have the grant INSERT ON test_kr831c2v.test_table. (ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37448) (comment: 03631_buffer_access_check.sh) (query 1, line 1) (in query: INSERT INTO test_kr831c2v.test_buffer VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e3a78db 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e3a3d96 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e3a2306 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e31aa78 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000031868a8c 8. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x00000000317cc65e 9. ./build_docker/./src/Storages/StorageBuffer.cpp:682: DB::BufferSink::consume(DB::Chunk&) @ 0x0000000038fc282f 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 18. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 19. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:12:36.425634 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.439843 [ 17376 ] {} TCPHandler: Code: 497. DB::Exception: user03631_test_kr831c2v_27565: Not enough privileges. To execute this query, it's necessary to have the grant INSERT ON test_kr831c2v.test_table. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e3a78db 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e3a3d96 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e3a2306 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e31aa78 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x0000000031868a8c 8. ./build_docker/./src/Interpreters/Context.cpp:1755: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x00000000317cc65e 9. ./build_docker/./src/Storages/StorageBuffer.cpp:682: DB::BufferSink::consume(DB::Chunk&) @ 0x0000000038fc282f 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 18. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 19. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:12:36.448717 [ 18771 ] {5252cbf6-5e7d-4466-85cb-5b7e905e061f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 679, line 680) (in query: SELECT h3IsPentagon(NULL, NULL, NULL);) 2025.11.13 09:12:36.453216 [ 10181 ] {2630ef31-b086-43af-b56d-4791569f270c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1150, line 1152) (in query: SELECT reinterpretAsUInt256(NULL, NULL, NULL);) 2025.11.13 09:12:36.462842 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.463369 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.484946 [ 10181 ] {24d3acfd-efdc-4067-9433-310c41c47bd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1151, line 1153) (in query: SELECT reinterpretAsUInt32(NULL, NULL, NULL);) 2025.11.13 09:12:36.491849 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.492509 [ 17655 ] {949aa05d-b86e-4e42-8f74-c48eed362c7c} executeQuery: Code: 47. DB::Exception: Identifier 'l.c' cannot be resolved from subquery with name l. In scope SELECT l.c FROM (SELECT 1 AS a, 2 AS b) AS l INNER JOIN (SELECT 2 AS b, 3 AS c) AS r USING (b). Maybe you meant: ['l.a']. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37478) (comment: 01034_unknown_qualified_column_in_join.sql) (query 1, line 1) (in query: SELECT l.c FROM (SELECT 1 AS a, 2 AS b) AS l join (SELECT 2 AS b, 3 AS c) AS r USING b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000031140d9f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:617: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000031128cf5 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112abcd 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1396: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eaa3 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:892: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&, bool) const @ 0x0000000031133f1a 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:900: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000311304ab 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eb0c 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000003113d802 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1498: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449f31 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:12:36.497093 [ 17655 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 'l.c' cannot be resolved from subquery with name l. In scope SELECT l.c FROM (SELECT 1 AS a, 2 AS b) AS l INNER JOIN (SELECT 2 AS b, 3 AS c) AS r USING (b). Maybe you meant: ['l.a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000031140d9f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:617: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000031128cf5 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112abcd 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1396: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eaa3 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:892: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&, bool) const @ 0x0000000031133f1a 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:900: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000311304ab 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eb0c 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000003113d802 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1498: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449f31 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:12:36.513583 [ 10181 ] {b7143302-007b-42f1-bd2f-828bb505601c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1152, line 1154) (in query: SELECT reinterpretAsUInt64(NULL, NULL, NULL);) 2025.11.13 09:12:36.524499 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.538443 [ 18771 ] {d44c9850-5cf2-43e4-8587-b9f5620a9b42} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 680, line 681) (in query: SELECT h3IsResClassIII(NULL, NULL, NULL);) 2025.11.13 09:12:36.542499 [ 10181 ] {3fbe19f4-14ce-41a5-a297-30a7287c72dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1153, line 1155) (in query: SELECT reinterpretAsUInt8(NULL, NULL, NULL);) 2025.11.13 09:12:36.553334 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.553554 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.570889 [ 10181 ] {771acf77-46f2-47e4-b2b3-93a89b4d1562} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1154, line 1156) (in query: SELECT reinterpretAsUUID(NULL, NULL, NULL);) 2025.11.13 09:12:36.571840 [ 18771 ] {f2dd7e4b-a4c7-4ce2-90f7-bd79742aeb7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 681, line 682) (in query: SELECT h3IsValid(NULL, NULL, NULL);) 2025.11.13 09:12:36.577073 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.581871 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.595510 [ 10181 ] {3e20a899-0d8b-4ef9-8016-8956d5a53a76} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1155, line 1157) (in query: SELECT repeat(NULL, NULL, NULL);) 2025.11.13 09:12:36.600625 [ 18771 ] {664f408f-0d26-4494-8ec6-09d29adb8955} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 682, line 683) (in query: SELECT h3Line(NULL, NULL, NULL);) 2025.11.13 09:12:36.601443 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.605283 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.627305 [ 18771 ] {4c52eee4-8dcf-4a50-9d7a-3f6c1669cce4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 683, line 684) (in query: SELECT h3NumHexagons(NULL, NULL, NULL);) 2025.11.13 09:12:36.634650 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.656379 [ 18771 ] {37e39c65-27bf-407f-90c8-e723a90b1a82} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 684, line 685) (in query: SELECT h3PointDistKm(NULL, NULL, NULL);) 2025.11.13 09:12:36.664963 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.686192 [ 18771 ] {c307948f-c209-41ef-ab58-a19acfeb19cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 685, line 686) (in query: SELECT h3PointDistM(NULL, NULL, NULL);) 2025.11.13 09:12:36.692550 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.714848 [ 18771 ] {49399306-c85d-4f27-9b64-e5884cba6442} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 686, line 687) (in query: SELECT h3PointDistRads(NULL, NULL, NULL);) 2025.11.13 09:12:36.721476 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.745366 [ 18771 ] {4a4ce3e5-97c3-4304-9e9c-8a4caa6bd130} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 687, line 688) (in query: SELECT h3ToCenterChild(NULL, NULL, NULL);) 2025.11.13 09:12:36.750553 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.773437 [ 18771 ] {ff98dcae-779e-49d5-bcf3-6592165dc890} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 688, line 689) (in query: SELECT h3ToChildren(NULL, NULL, NULL);) 2025.11.13 09:12:36.778646 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.861984 [ 18771 ] {7672240b-bcf1-49f4-aa66-7efc25bb69e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 689, line 690) (in query: SELECT h3ToGeo(NULL, NULL, NULL);) 2025.11.13 09:12:36.869500 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.902444 [ 18771 ] {8badfb3d-489e-4ce5-9dd9-2e8a8615929b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 690, line 691) (in query: SELECT h3ToGeoBoundary(NULL, NULL, NULL);) 2025.11.13 09:12:36.907951 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.931395 [ 18771 ] {ac6f0bae-e47a-40e4-8cea-bb57d35aa219} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 691, line 692) (in query: SELECT h3ToParent(NULL, NULL, NULL);) 2025.11.13 09:12:36.936470 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.961685 [ 18771 ] {067fbdcf-68d9-45bb-938d-d02ddda5a496} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 692, line 693) (in query: SELECT h3ToString(NULL, NULL, NULL);) 2025.11.13 09:12:36.966651 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.992003 [ 18771 ] {f9ba1413-f52a-491f-9782-91c80933c116} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 693, line 694) (in query: SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL);) 2025.11.13 09:12:36.993066 [ 10181 ] {942e62d6-f29a-4c33-b490-01a93b5ad69b} executeQuery: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1161, line 1163) (in query: SELECT replicate(NULL, NULL, NULL);) 2025.11.13 09:12:36.996942 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:36.997498 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:37.087561 [ 18771 ] {563a3b61-65f0-4f71-8ccf-0e1efe5fa854} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 694, line 695) (in query: SELECT h3kRing(NULL, NULL, NULL);) 2025.11.13 09:12:37.093963 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.146167 [ 10181 ] {a7bd00b8-b3f2-465b-b6da-f999c4daf90a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1163, line 1165) (in query: SELECT reverse(NULL, NULL, NULL);) 2025.11.13 09:12:37.154146 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.174075 [ 10181 ] {c3539b2f-4a33-4015-9ce5-edcaa37b6d4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1164, line 1166) (in query: SELECT reverseUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:37.179132 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.199112 [ 10181 ] {68a8573e-1207-4f4e-948a-1c461004ec8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1165, line 1167) (in query: SELECT revision(NULL, NULL, NULL);) 2025.11.13 09:12:37.204129 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.224138 [ 10181 ] {5cd9b526-a48d-43e7-bf41-4f0df55b75f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1166, line 1168) (in query: SELECT right(NULL, NULL, NULL);) 2025.11.13 09:12:37.228957 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.252211 [ 18771 ] {f8fa592a-d40d-4807-a8b2-5108204c83dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 696, line 697) (in query: SELECT has(NULL, NULL, NULL);) 2025.11.13 09:12:37.261413 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.280938 [ 18771 ] {0ef332bf-28db-4592-a508-fde9dc6cf33a} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 697, line 698) (in query: SELECT hasAll(NULL, NULL, NULL);) 2025.11.13 09:12:37.285792 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.310383 [ 18771 ] {e98f5736-0584-497b-827e-5c86a2a962a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 698, line 699) (in query: SELECT hasAny(NULL, NULL, NULL);) 2025.11.13 09:12:37.315122 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.346313 [ 10181 ] {dd244be0-7fc1-42ee-b312-3686885d1633} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1169, line 1171) (in query: SELECT rightUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:37.351240 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.385321 [ 18771 ] {fb2e71a0-eb57-4b6c-9d6f-fb7b171a103c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 700, line 701) (in query: SELECT hasSubsequence(NULL, NULL, NULL);) 2025.11.13 09:12:37.389963 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.416852 [ 18771 ] {256cf904-7d8c-4b7a-b875-191d23ac99c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 701, line 702) (in query: SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:37.423099 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.450402 [ 18771 ] {01a20558-13e3-4cdf-801c-03542b1b64f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 702, line 703) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:37.458317 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.478921 [ 10181 ] {e3f6d74c-53af-497b-8e41-07a0c1a333af} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1171, line 1173) (in query: SELECT roundAge(NULL, NULL, NULL);) 2025.11.13 09:12:37.483727 [ 18771 ] {052b0aac-0a99-4190-8868-4c78bf1b6c75} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 703, line 704) (in query: SELECT hasSubsequenceUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:37.489373 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.494314 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.516872 [ 18771 ] {946a61cf-2e58-453d-a3a2-88f941de898e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 704, line 705) (in query: SELECT hasSubstr(NULL, NULL, NULL);) 2025.11.13 09:12:37.523192 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.548101 [ 10181 ] {fb7ad230-94c5-41ad-be39-04df1d9aeb1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1173, line 1175) (in query: SELECT roundDown(NULL, NULL, NULL);) 2025.11.13 09:12:37.550886 [ 18771 ] {d6397f47-5910-48d5-9d70-863d29a206b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 705, line 706) (in query: SELECT hasThreadFuzzer(NULL, NULL, NULL);) 2025.11.13 09:12:37.553985 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.557845 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.564943 [ 17655 ] {0d8a0dd1-472c-437e-bf6b-129647d3cb5e} executeQuery: Code: 47. DB::Exception: Identifier 'r.a' cannot be resolved from subquery with name r. In scope SELECT r.a FROM (SELECT 1 AS a, 2 AS b) AS l INNER JOIN (SELECT 2 AS b, 3 AS c) AS r USING (b). Maybe you meant: ['r.b']. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37478) (comment: 01034_unknown_qualified_column_in_join.sql) (query 2, line 2) (in query: SELECT r.a FROM (SELECT 1 AS a, 2 AS b) AS l join (SELECT 2 AS b, 3 AS c) AS r USING b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000031140d9f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:617: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000031128cf5 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112abcd 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1396: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eaa3 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:892: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&, bool) const @ 0x0000000031133d63 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:901: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000031130587 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eb0c 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000003113d802 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1498: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449f31 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:12:37.568790 [ 17655 ] {} TCPHandler: Code: 47. DB::Exception: Identifier 'r.a' cannot be resolved from subquery with name r. In scope SELECT r.a FROM (SELECT 1 AS a, 2 AS b) AS l INNER JOIN (SELECT 2 AS b, 3 AS c) AS r USING (b). Maybe you meant: ['r.b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x0000000031140d9f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:617: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x0000000031128cf5 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112abcd 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1396: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eaa3 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:892: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&)::$_0::operator()(std::shared_ptr const&, bool) const @ 0x0000000031133d63 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:901: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000031130587 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1376: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003112eb0c 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000003113d802 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1498: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449f31 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:12:37.572911 [ 10181 ] {a6d65404-6698-431f-9c04-935b3f6ec77d} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1174, line 1176) (in query: SELECT roundDuration(NULL, NULL, NULL);) 2025.11.13 09:12:37.581547 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.584185 [ 18771 ] {5ad67a19-4ea0-4af2-b359-b87d93e32f4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 706, line 707) (in query: SELECT hasToken(NULL, NULL, NULL);) 2025.11.13 09:12:37.590068 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.599509 [ 10181 ] {faeb375f-2ae9-4542-bed7-611c18e03c78} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1175, line 1177) (in query: SELECT roundToExp2(NULL, NULL, NULL);) 2025.11.13 09:12:37.604174 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.611878 [ 18771 ] {2499bd0f-0f5b-483f-9e2f-c2dc5be0abf2} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 707, line 708) (in query: SELECT hasTokenCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:37.617131 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.656783 [ 10181 ] {b3345f6b-23a0-4b16-92af-6cca243875eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1176, line 1178) (in query: SELECT rowNumberInAllBlocks(NULL, NULL, NULL);) 2025.11.13 09:12:37.661444 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.685253 [ 10181 ] {503779fd-9123-4c75-a195-61e185071a33} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1177, line 1179) (in query: SELECT rowNumberInBlock(NULL, NULL, NULL);) 2025.11.13 09:12:37.685425 [ 16199 ] {5254613e-b734-4482-b526-79748fe7b222} executeQuery: Code: 36. DB::Exception: Cannot drop or clear columns 'nes.b, nes.a', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (in query: /* ddl_entry=query-0000000004 */ ALTER TABLE test_px1cmqla.`02500_nested` (DROP COLUMN nes)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000039a92377 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4012: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922e6b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:37.690631 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.695205 [ 16199 ] {5254613e-b734-4482-b526-79748fe7b222} executeQuery: Code: 36. DB::Exception: Cannot drop or clear columns 'nes.b, nes.a', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37470) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (query 6, line 8) (in query: ALTER TABLE 02500_nested DROP COLUMN nes;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000039a92377 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4012: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922e6b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:37.698744 [ 16199 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear columns 'nes.b, nes.a', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000039a92377 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4012: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922e6b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:37.722521 [ 18771 ] {0d2dac27-d859-4254-a78f-27a0ed02189c} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 708, line 709) (in query: SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:37.727421 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.755005 [ 18771 ] {c377eeac-000e-4a68-9fd8-1ca54df5bc0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 709, line 710) (in query: SELECT hasTokenOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:37.759988 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.788843 [ 18771 ] {6b29d06d-e451-43cc-912f-66a564b69d49} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 710, line 711) (in query: SELECT hex(NULL, NULL, NULL);) 2025.11.13 09:12:37.794256 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.820193 [ 18771 ] {5ead419a-1f7e-41ae-aecd-4b82505c080e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 711, line 712) (in query: SELECT hilbertDecode(NULL, NULL, NULL);) 2025.11.13 09:12:37.821177 [ 10181 ] {f05e9620-71e3-4485-8a43-e9bd35d56ce7} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1178, line 1180) (in query: SELECT row_number(NULL, NULL, NULL);) 2025.11.13 09:12:37.826289 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:37.829982 [ 10181 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:12:37.979767 [ 10181 ] {49d87d8c-c063-4233-bd76-30cd2ef337ad} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1180, line 1183) (in query: SELECT runningAccumulate(NULL, NULL, NULL);) 2025.11.13 09:12:37.985173 [ 10181 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:12:38.008196 [ 10181 ] {838f5448-51e1-4230-a391-74a5f09e2a68} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1181, line 1184) (in query: SELECT runningConcurrency(NULL, NULL, NULL);) 2025.11.13 09:12:38.012946 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.035881 [ 10181 ] {40824ce0-9d03-4c67-b873-2c470d2212ec} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1182, line 1185) (in query: SELECT runningDifference(NULL, NULL, NULL);) 2025.11.13 09:12:38.041567 [ 10181 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:12:38.061139 [ 10181 ] {bdcf5d84-7844-40de-ad4a-356facbf3844} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1183, line 1186) (in query: SELECT runningDifferenceStartingWithFirstValue(NULL, NULL, NULL);) 2025.11.13 09:12:38.066291 [ 10181 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:12:38.198617 [ 16198 ] {3e45b492-4e0a-47a2-8c30-112af9d0b3ee} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 0.00 B (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37346) (comment: 01786_group_by_pk_many_streams.sql) (query 6, line 13) (in query: SELECT sum(v) AS s FROM group_by_pk GROUP BY k ORDER BY s DESC LIMIT 5 SETTINGS optimize_aggregation_in_order = 0, max_block_size = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:12:38.204022 [ 10181 ] {9ffb4434-a972-4fbe-9b14-553c94ccfc74} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1185, line 1188) (in query: SELECT s2CapUnion(NULL, NULL, NULL);) 2025.11.13 09:12:38.211418 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.212599 [ 16198 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 0.00 B (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:38.229409 [ 10181 ] {5e96c20e-affd-4892-be5b-df06c1863f9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1186, line 1189) (in query: SELECT s2CellsIntersect(NULL, NULL, NULL);) 2025.11.13 09:12:38.237508 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.261369 [ 10181 ] {72ffc16f-c2fe-4baf-8057-7b5640a8d49b} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1187, line 1190) (in query: SELECT s2GetNeighbors(NULL, NULL, NULL);) 2025.11.13 09:12:38.266283 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.341847 [ 18771 ] {567277e9-23f7-4aed-a166-3246f5652ba5} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 718, line 719) (in query: SELECT hostName(NULL, NULL, NULL);) 2025.11.13 09:12:38.346840 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.374597 [ 18771 ] {96f12fc6-ec89-4afe-8d26-830c9e5e710f} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 719, line 720) (in query: SELECT hostname(NULL, NULL, NULL);) 2025.11.13 09:12:38.380482 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.404546 [ 18771 ] {91cdf3f8-4da9-410b-8dfb-16f59436658e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 720, line 721) (in query: SELECT hypot(NULL, NULL, NULL);) 2025.11.13 09:12:38.409798 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.435471 [ 18771 ] {8c893b47-74e3-4680-9e17-3344e6e18019} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 3, should be 2: In scope SELECT icebergTruncate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 721, line 722) (in query: SELECT icebergTruncate(NULL, NULL, NULL);) 2025.11.13 09:12:38.440393 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 3, should be 2: In scope SELECT icebergTruncate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.463493 [ 18771 ] {f828c6a3-5d0c-41ba-8be1-f67bb3692381} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 722, line 723) (in query: SELECT identity(NULL, NULL, NULL);) 2025.11.13 09:12:38.468147 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.492657 [ 18771 ] {95b47ed8-981e-4e59-a37c-ec68620856a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 723, line 724) (in query: SELECT idnaDecode(NULL, NULL, NULL);) 2025.11.13 09:12:38.497284 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.521965 [ 18771 ] {0fc83720-1ec3-449b-af90-7419b51c6872} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 724, line 725) (in query: SELECT idnaEncode(NULL, NULL, NULL);) 2025.11.13 09:12:38.526627 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.560400 [ 10181 ] {8ee77b78-1361-481d-afda-e87e85362bfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1190, line 1193) (in query: SELECT s2RectIntersection(NULL, NULL, NULL);) 2025.11.13 09:12:38.594285 [ 18771 ] {04c64e3f-8b89-4ac6-a5f1-2b4cf6085c93} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 726, line 727) (in query: SELECT ifNotFinite(NULL, NULL, NULL);) 2025.11.13 09:12:38.600789 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.635648 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.656558 [ 10181 ] {82979df7-13f6-4a96-a411-68faffeb460b} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1191, line 1194) (in query: SELECT s2RectUnion(NULL, NULL, NULL);) 2025.11.13 09:12:38.661445 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.684136 [ 10181 ] {f649d2f0-514e-4bfd-8ead-a370274d8121} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1192, line 1195) (in query: SELECT s2ToGeo(NULL, NULL, NULL);) 2025.11.13 09:12:38.781183 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.782017 [ 18771 ] {c0637f28-f4ec-426d-808c-f34d070c73b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 727, line 728) (in query: SELECT ifNull(NULL, NULL, NULL);) 2025.11.13 09:12:38.787069 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:38.802438 [ 10181 ] {660bf8dc-a70d-4152-9908-7a325ec9e58b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1193, line 1196) (in query: SELECT scalarProduct(NULL, NULL, NULL);) 2025.11.13 09:12:38.807697 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.052012 [ 18771 ] {a7b14ee3-ca38-4200-8a3c-231668faa2a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 729, line 730) (in query: SELECT ilike(NULL, NULL, NULL);) 2025.11.13 09:12:39.057521 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.085870 [ 18771 ] {dbe1b90c-fc3d-45cf-a598-e0bafa054f20} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 730, line 731) (in query: SELECT in(NULL, NULL, NULL);) 2025.11.13 09:12:39.088012 [ 10181 ] {58552c81-d267-4150-9d06-71a6ecf39cff} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1197, line 1200) (in query: SELECT sequenceNextNode(NULL, NULL, NULL);) 2025.11.13 09:12:39.091684 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.099733 [ 10181 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.11.13 09:12:39.116812 [ 10181 ] {46d4cdc9-d819-4610-9cb8-1d7888e3db10} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1198, line 1201) (in query: SELECT seriesDecomposeSTL(NULL, NULL, NULL);) 2025.11.13 09:12:39.117145 [ 18771 ] {bad345e8-efb2-4f37-b269-bb71809e2b73} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 731, line 732) (in query: SELECT inIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:39.122656 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.126167 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.188816 [ 10181 ] {aeda1910-4cca-4237-b6cf-821b4d40b9c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1200, line 1203) (in query: SELECT seriesPeriodDetectFFT(NULL, NULL, NULL);) 2025.11.13 09:12:39.193589 [ 18771 ] {cf1cd273-4476-4d87-8e8b-f2734b85c36e} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 733, line 734) (in query: SELECT indexOf(NULL, NULL, NULL);) 2025.11.13 09:12:39.194008 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.198035 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.201018 [ 16199 ] {c0f6910c-94b4-49ac-bf3c-266a2c16f215} executeQuery: Code: 36. DB::Exception: Cannot drop or clear column 'nes', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (in query: /* ddl_entry=query-0000000011 */ ALTER TABLE test_px1cmqla.`02500_nested` (DROP COLUMN nes)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000039a92377 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4012: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922e6b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:39.210613 [ 16199 ] {c0f6910c-94b4-49ac-bf3c-266a2c16f215} executeQuery: Code: 36. DB::Exception: Cannot drop or clear column 'nes', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37470) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (query 16, line 21) (in query: ALTER TABLE 02500_nested DROP COLUMN nes;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000039a92377 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4012: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922e6b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:39.211574 [ 10181 ] {e6019c18-0680-464e-a271-64f4c4b0d418} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1201, line 1204) (in query: SELECT serverTimeZone(NULL, NULL, NULL);) 2025.11.13 09:12:39.214274 [ 16199 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear column 'nes', because all columns in part 'all_1_1_0' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x0000000039a92377 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4012: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922e6b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:39.215380 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.226109 [ 18771 ] {415a0bc0-a0a9-4e8a-9a5b-c8a1c874dda6} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 734, line 735) (in query: SELECT indexOfAssumeSorted(NULL, NULL, NULL);) 2025.11.13 09:12:39.231072 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.237217 [ 10181 ] {f9739e2e-0154-4340-bf0e-0febb31ea28b} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1202, line 1205) (in query: SELECT serverTimezone(NULL, NULL, NULL);) 2025.11.13 09:12:39.241670 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.253454 [ 18771 ] {aec9b4f6-b04e-4784-8dd1-75c0c9430bea} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 735, line 736) (in query: SELECT initcap(NULL, NULL, NULL);) 2025.11.13 09:12:39.258872 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.276179 [ 16315 ] {570bbcfd-3d9c-4653-bb49-b62f9294b187} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53112) (comment: 03031_read_in_order_optimization_with_virtual_row.sql) (query 47, line 212) (in query: SELECT DISTINCT a FROM distinct_in_order ORDER BY a ASC SETTINGS read_in_order_two_level_merge_threshold = 0, optimize_read_in_order = 1, max_threads = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:12:39.280515 [ 18771 ] {500237b6-f843-4a0b-87b5-720b10fd8084} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 736, line 737) (in query: SELECT initcapUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:39.283760 [ 16315 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:39.285139 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.310219 [ 18771 ] {a1195cb9-56db-44cf-9ab0-5cf36e7753fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 737, line 738) (in query: SELECT initialQueryID(NULL, NULL, NULL);) 2025.11.13 09:12:39.315718 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.326209 [ 10181 ] {a38a0c67-d26d-4ad0-aa1d-c7f8433f2de2} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1203, line 1206) (in query: SELECT serverUUID(NULL, NULL, NULL);) 2025.11.13 09:12:39.332321 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.339144 [ 18771 ] {a4ddc03d-0a8a-4474-89c6-613fd9fde152} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initialQueryStartTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 738, line 739) (in query: SELECT initialQueryStartTime(NULL, NULL, NULL);) 2025.11.13 09:12:39.344166 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initialQueryStartTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.352646 [ 10181 ] {ca5dfa24-0aa8-4bc0-92ff-678b6c80f635} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1204, line 1207) (in query: SELECT shardCount(NULL, NULL, NULL);) 2025.11.13 09:12:39.357535 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.377715 [ 10181 ] {32d8799a-d426-49d5-b177-acd5ee9f1b88} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1205, line 1208) (in query: SELECT shardNum(NULL, NULL, NULL);) 2025.11.13 09:12:39.383546 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.399554 [ 18771 ] {75327cb7-ff8e-49a5-a803-e915e3266327} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 739, line 740) (in query: SELECT initial_query_id(NULL, NULL, NULL);) 2025.11.13 09:12:39.401125 [ 10181 ] {6cd2cd37-aa2d-43d5-9dd1-365cd55762b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1206, line 1209) (in query: SELECT showCertificate(NULL, NULL, NULL);) 2025.11.13 09:12:39.405871 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.406605 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.509308 [ 10181 ] {84ce9af3-e3e2-4cdd-a37d-50d74beb2df7} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1207, line 1210) (in query: SELECT sigmoid(NULL, NULL, NULL);) 2025.11.13 09:12:39.509308 [ 18771 ] {682d452d-7ab1-48b8-acf5-a121ea457ef5} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initial_query_start_time(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 740, line 741) (in query: SELECT initial_query_start_time(NULL, NULL, NULL);) 2025.11.13 09:12:39.514100 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initial_query_start_time(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.514127 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.536222 [ 10181 ] {3ec5c593-f719-4dea-aaba-dfe70bce09b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1208, line 1211) (in query: SELECT sign(NULL, NULL, NULL);) 2025.11.13 09:12:39.537038 [ 18771 ] {3f0e6524-52e1-4e18-b182-4621b7841f56} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 741, line 742) (in query: SELECT initializeAggregation(NULL, NULL, NULL);) 2025.11.13 09:12:39.540800 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.540813 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:39.561980 [ 10181 ] {f4eabe3f-93c5-41f9-a537-94c31fb29894} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1209, line 1212) (in query: SELECT simpleJSONExtractBool(NULL, NULL, NULL);) 2025.11.13 09:12:39.572702 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.588184 [ 10181 ] {c14a999c-f794-4085-bc22-a560d2746d06} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1210, line 1213) (in query: SELECT simpleJSONExtractFloat(NULL, NULL, NULL);) 2025.11.13 09:12:39.594056 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.611399 [ 18771 ] {4c0e58a3-6ad7-40f5-b9f3-f97b63401bfe} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 743, line 744) (in query: SELECT intDiv(NULL, NULL, NULL);) 2025.11.13 09:12:39.612272 [ 10181 ] {84b48026-0c6c-4b43-b24f-97fc001bd24a} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1211, line 1214) (in query: SELECT simpleJSONExtractInt(NULL, NULL, NULL);) 2025.11.13 09:12:39.617755 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.617778 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.636753 [ 10181 ] {66c832ab-d19a-40b0-aa06-217e311186ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1212, line 1215) (in query: SELECT simpleJSONExtractRaw(NULL, NULL, NULL);) 2025.11.13 09:12:39.638826 [ 18771 ] {9a266876-c4b6-4ae4-b19a-f270d56f626a} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 744, line 745) (in query: SELECT intDivOrZero(NULL, NULL, NULL);) 2025.11.13 09:12:39.643049 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.644417 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.661654 [ 10181 ] {9e134790-e7e3-47d8-a7f7-061dc1e46e4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1213, line 1216) (in query: SELECT simpleJSONExtractString(NULL, NULL, NULL);) 2025.11.13 09:12:39.666997 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.676704 [ 18771 ] {43040923-cb69-416b-9ee1-34d3a36fb324} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 745, line 746) (in query: SELECT intExp10(NULL, NULL, NULL);) 2025.11.13 09:12:39.681187 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.687564 [ 10181 ] {30bd5a6c-f763-4a52-a1f0-4d882a3364bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1214, line 1217) (in query: SELECT simpleJSONExtractUInt(NULL, NULL, NULL);) 2025.11.13 09:12:39.692643 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.705901 [ 18771 ] {6d1d3369-d01c-4fb6-8ef3-fd1a230f0bb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 746, line 747) (in query: SELECT intExp2(NULL, NULL, NULL);) 2025.11.13 09:12:39.711549 [ 10181 ] {6bbea6d6-a2cf-4278-9693-b2c3793ca178} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1215, line 1218) (in query: SELECT simpleJSONHas(NULL, NULL, NULL);) 2025.11.13 09:12:39.716386 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.718956 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.736294 [ 18771 ] {453dc8f0-70cc-4516-bb58-c70e19833534} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 747, line 748) (in query: SELECT intHash32(NULL, NULL, NULL);) 2025.11.13 09:12:39.741940 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.763088 [ 18771 ] {4525fe94-3325-4337-8c3d-534af70e6638} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 748, line 749) (in query: SELECT intHash64(NULL, NULL, NULL);) 2025.11.13 09:12:39.767486 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.803250 [ 10181 ] {d29b7ae8-816a-4a22-8e8a-acce97b8d581} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1217, line 1220) (in query: SELECT sin(NULL, NULL, NULL);) 2025.11.13 09:12:39.808822 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.838389 [ 18771 ] {4c4c5c5d-b252-46ab-b925-80087ee7af6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 750, line 751) (in query: SELECT isConstant(NULL, NULL, NULL);) 2025.11.13 09:12:39.843048 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:39.873450 [ 10181 ] {c6412501-7200-4fb2-bbbc-52195b011943} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1219, line 1222) (in query: SELECT sinh(NULL, NULL, NULL);) 2025.11.13 09:12:39.878476 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.029047 [ 18771 ] {6e661b1f-3bdd-416a-870d-1cc2bb3b3a0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 752, line 753) (in query: SELECT isDynamicElementInSharedData(NULL, NULL, NULL);) 2025.11.13 09:12:40.047619 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.068401 [ 18771 ] {11dc1146-32fc-40de-8eb4-da2bb8d8ec41} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 753, line 754) (in query: SELECT isFinite(NULL, NULL, NULL);) 2025.11.13 09:12:40.073870 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.102676 [ 18771 ] {d5501055-5db6-4eed-9d18-0a1a7e8b7feb} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 754, line 755) (in query: SELECT isIPAddressInRange(NULL, NULL, NULL);) 2025.11.13 09:12:40.108200 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.131930 [ 18771 ] {0024cfc0-f16d-4636-b7e6-6a4f4a9a814a} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 755, line 756) (in query: SELECT isIPv4String(NULL, NULL, NULL);) 2025.11.13 09:12:40.137288 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.170917 [ 18771 ] {3eb794d0-195f-454b-bf8d-14eea67f5d0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 756, line 757) (in query: SELECT isIPv6String(NULL, NULL, NULL);) 2025.11.13 09:12:40.176408 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.203656 [ 18771 ] {7c304817-a610-4408-bf38-21971f987732} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 757, line 758) (in query: SELECT isInfinite(NULL, NULL, NULL);) 2025.11.13 09:12:40.210177 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.237168 [ 18771 ] {6bef7980-c120-4f69-b624-45ce6015b73c} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 758, line 759) (in query: SELECT isNaN(NULL, NULL, NULL);) 2025.11.13 09:12:40.242396 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.270549 [ 18771 ] {1fbca351-9281-4cbe-ac07-938cedff2f59} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 759, line 760) (in query: SELECT isNotDistinctFrom(NULL, NULL, NULL);) 2025.11.13 09:12:40.276095 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.299150 [ 18771 ] {e2a2c0d9-fdac-49cf-8a8a-8ef0e552c1cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 760, line 761) (in query: SELECT isNotNull(NULL, NULL, NULL);) 2025.11.13 09:12:40.303797 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.432034 [ 18771 ] {f974d58e-a1a6-4176-ac32-dcf413f45aaf} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 761, line 762) (in query: SELECT isNull(NULL, NULL, NULL);) 2025.11.13 09:12:40.441409 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.466700 [ 18771 ] {28c339e3-7d12-48d7-9ab8-b59babb5dfd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 762, line 763) (in query: SELECT isNullable(NULL, NULL, NULL);) 2025.11.13 09:12:40.558117 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.575363 [ 10181 ] {990f520c-51ef-4d76-acb4-999bf9d32c48} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1228, line 1231) (in query: SELECT sleep(NULL, NULL, NULL);) 2025.11.13 09:12:40.582248 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.585013 [ 18771 ] {d6cf5fad-c8fa-47c8-ae67-3f8a68ce4d5e} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 763, line 764) (in query: SELECT isValidJSON(NULL, NULL, NULL);) 2025.11.13 09:12:40.600601 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.608096 [ 10181 ] {08a5ea02-f539-4916-97c7-2065f59867d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1229, line 1232) (in query: SELECT sleepEachRow(NULL, NULL, NULL);) 2025.11.13 09:12:40.618069 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.619579 [ 18771 ] {3b7bab99-d05e-41bb-83b1-4105c55c2351} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 764, line 765) (in query: SELECT isValidUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:40.635392 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.654981 [ 18771 ] {a9391a31-081f-4c5e-8138-3cda2e674736} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 765, line 766) (in query: SELECT isZeroOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:40.661711 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.685232 [ 18771 ] {953fe4c6-6ca7-43e8-ba6b-1818c158138e} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 766, line 767) (in query: SELECT jaroSimilarity(NULL, NULL, NULL);) 2025.11.13 09:12:40.691105 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.766771 [ 18771 ] {e9c1eca4-8c1c-491e-8742-74b82232cb91} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 767, line 768) (in query: SELECT jaroWinklerSimilarity(NULL, NULL, NULL);) 2025.11.13 09:12:40.772565 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.924160 [ 10181 ] {3dcc4034-3b94-46ba-8a3e-b7dc900da464} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1234, line 1237) (in query: SELECT soundex(NULL, NULL, NULL);) 2025.11.13 09:12:40.930200 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.956676 [ 10181 ] {5a9523b9-b26f-42e6-9365-da19441e861b} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1235, line 1238) (in query: SELECT space(NULL, NULL, NULL);) 2025.11.13 09:12:40.963884 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:40.973153 [ 18771 ] {14468c13-fc01-4c87-9097-cecdb204cb82} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 770, line 771) (in query: SELECT joinGet(NULL, NULL, NULL);) 2025.11.13 09:12:40.978018 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:41.004946 [ 18771 ] {a0c0ab49-9c58-40f6-bbe6-e56a3532bfcc} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 771, line 772) (in query: SELECT joinGetOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:41.012551 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:41.086728 [ 18771 ] {e1dbb82b-47c0-4cb8-8bf2-da9599cb80e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 773, line 774) (in query: SELECT jumpConsistentHash(NULL, NULL, NULL);) 2025.11.13 09:12:41.178822 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:41.255674 [ 18771 ] {f5482c9d-2c91-47aa-ba37-5713581f2f7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 3, should be 1: In scope SELECT keccak256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 775, line 776) (in query: SELECT keccak256(NULL, NULL, NULL);) 2025.11.13 09:12:41.260940 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 3, should be 1: In scope SELECT keccak256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:41.415117 [ 18771 ] {ccbb1b77-1825-43c6-9bf2-d98737701bf4} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 777, line 778) (in query: SELECT kostikConsistentHash(NULL, NULL, NULL);) 2025.11.13 09:12:41.420010 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:41.552172 [ 10181 ] {c077d4c0-401f-4afc-b7fa-277d4e286582} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1245, line 1248) (in query: SELECT sqidDecode(NULL, NULL, NULL);) 2025.11.13 09:12:41.556986 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:41.636174 [ 10181 ] {745cd2be-832a-4a18-a2f1-1f8c2e0f8f45} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1247, line 1250) (in query: SELECT sqrt(NULL, NULL, NULL);) 2025.11.13 09:12:41.642147 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:41.663832 [ 10181 ] {d8e602dd-a8d4-4e54-86d1-0a95ebd7ffbc} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1248, line 1251) (in query: SELECT startsWith(NULL, NULL, NULL);) 2025.11.13 09:12:41.668630 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:41.731562 [ 10181 ] {66cc407f-5e19-460c-8519-b15765bc7c60} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1249, line 1252) (in query: SELECT startsWithUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:41.736145 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.002207 [ 18771 ] {59485d6a-60ae-48f9-bb8b-93e8195bc446} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 782, line 783) (in query: SELECT lagInFrame(NULL, NULL, NULL);) 2025.11.13 09:12:42.010371 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.11.13 09:12:42.063270 [ 10177 ] {326ca924-0bc8-4dc9-93db-c8a8f7bf3a47} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60420) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_tg91tviv`.`test_parallel_replicas_automatic_count` AS `__table1` WHERE `__table1`.`number` < 500000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:12:42.071708 [ 10177 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:42.139901 [ 17376 ] {8091c18d-9fc1-4782-a433-fffe58dd6995} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=854). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37566) (comment: 00700_decimal_null.sql) (query 41, line 57) (in query: SELECT count() FROM decimal WHERE d IS NULL AND f IS NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:42.143914 [ 10181 ] {8f4f17d3-bf5d-4f99-b29d-01a2b6522fc1} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1254, line 1257) (in query: SELECT stem(NULL, NULL, NULL);) 2025.11.13 09:12:42.147378 [ 18771 ] {7c9a6048-c642-48f9-9693-8913519601e3} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 784, line 785) (in query: SELECT lastValueRespectNulls(NULL, NULL, NULL);) 2025.11.13 09:12:42.153598 [ 10181 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:12:42.156840 [ 17389 ] {da57d11b-da81-4132-9868-8627aaebfb1d} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37666) (comment: 02231_hierarchical_dictionaries_constant.sql) (query 38, line 53) (in query: DROP DICTIONARY hierarchy_flat_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:12:42.159726 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.162761 [ 17376 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=854). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:42.163874 [ 17389 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:12:42.178284 [ 17227 ] {02784_automatic_parallel_replicas-test_tg91tviv_index_100k_pure} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46204) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count WHERE number < 500_000 SETTINGS use_query_condition_cache = 0 format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:12:42.201382 [ 17227 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:42.243760 [ 18771 ] {7809541a-9458-49c6-a928-722e612ad81a} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 786, line 787) (in query: SELECT last_value_respect_nulls(NULL, NULL, NULL);) 2025.11.13 09:12:42.254955 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.271457 [ 18771 ] {d935f9be-f213-4cce-b662-673dcf57a79f} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 787, line 788) (in query: SELECT lcase(NULL, NULL, NULL);) 2025.11.13 09:12:42.282064 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.305360 [ 18771 ] {063b8b20-69bc-47be-b5ab-42a014537dc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 788, line 789) (in query: SELECT lcm(NULL, NULL, NULL);) 2025.11.13 09:12:42.309313 [ 4550 ] {8e02221b-9283-4d28-acef-b18f89004977} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45396, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45396) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_tg91tviv`.`test_parallel_replicas_automatic_count` AS `__table1` WHERE `__table1`.`number` < 500000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003aefd4ae 8. ./build_docker/./src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed460c 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:42.313147 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.314877 [ 4550 ] {8e02221b-9283-4d28-acef-b18f89004977} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:45396). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x000000003aea5649 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:42.334482 [ 4550 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45396, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003aefd4ae 8. ./build_docker/./src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed460c 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:42.337983 [ 18771 ] {3719bb66-dbf1-4439-9b51-4595e259050f} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 789, line 790) (in query: SELECT leadInFrame(NULL, NULL, NULL);) 2025.11.13 09:12:42.344503 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.11.13 09:12:42.410999 [ 10181 ] {90f889c2-405a-4ce1-9abe-02800d154696} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1259, line 1262) (in query: SELECT stringJaccardIndex(NULL, NULL, NULL);) 2025.11.13 09:12:42.418191 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.425642 [ 18771 ] {9139694d-3abd-4da0-899a-f5aa2c665efe} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 791, line 792) (in query: SELECT left(NULL, NULL, NULL);) 2025.11.13 09:12:42.431181 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.436983 [ 10181 ] {597f0c76-0276-4505-bc0b-e2df5726e7ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1260, line 1263) (in query: SELECT stringJaccardIndexUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:42.444608 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.460564 [ 10181 ] {30bce669-4ab2-46a0-88aa-2f3a226e5d1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1261, line 1264) (in query: SELECT stringToH3(NULL, NULL, NULL);) 2025.11.13 09:12:42.469582 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.487848 [ 10181 ] {30614d64-ce47-43ab-b5ea-580099159964} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1262, line 1265) (in query: SELECT structureToCapnProtoSchema(NULL, NULL, NULL);) 2025.11.13 09:12:42.501584 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.519497 [ 10181 ] {16972040-cb44-4977-b040-31f23bc6d87e} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1263, line 1266) (in query: SELECT structureToProtobufSchema(NULL, NULL, NULL);) 2025.11.13 09:12:42.531142 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.651644 [ 10181 ] {fdcd971a-2223-475d-9006-a3ce7b9ea683} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1266, line 1269) (in query: SELECT subDate(NULL, NULL, NULL);) 2025.11.13 09:12:42.657514 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.669452 [ 18771 ] {ffb4a8e9-14c6-4f30-afed-b4df2bd6267d} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 794, line 795) (in query: SELECT leftUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:42.684561 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.712532 [ 18771 ] {a9dd9669-bab4-4134-8a68-cd72d7a95c25} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 795, line 796) (in query: SELECT lemmatize(NULL, NULL, NULL);) 2025.11.13 09:12:42.727879 [ 18771 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:12:42.747407 [ 18771 ] {3d44ff87-e734-43ee-bb06-448fcc66d912} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 796, line 797) (in query: SELECT length(NULL, NULL, NULL);) 2025.11.13 09:12:42.762365 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.781605 [ 18771 ] {9eaf6d2c-5a5a-4592-8790-72188ee15322} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 797, line 798) (in query: SELECT lengthUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:42.786680 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.814581 [ 18771 ] {6c8fd727-f778-44de-b581-4acff39d375c} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 798, line 799) (in query: SELECT less(NULL, NULL, NULL);) 2025.11.13 09:12:42.827032 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.845522 [ 18771 ] {c2545fa4-4a9e-4959-92a0-d80d9f06dc34} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 799, line 800) (in query: SELECT lessOrEquals(NULL, NULL, NULL);) 2025.11.13 09:12:42.852067 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:42.937069 [ 18771 ] {c33a5de2-fc79-402a-87e6-a3410a763edc} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 800, line 801) (in query: SELECT levenshteinDistance(NULL, NULL, NULL);) 2025.11.13 09:12:42.943643 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.060453 [ 18771 ] {7d00f58b-bec5-4bc9-9f36-60ac020a89f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 801, line 802) (in query: SELECT levenshteinDistanceUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:43.074021 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.092160 [ 18771 ] {cb4a06fe-fb91-4a85-b597-4ad31f8190e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 802, line 803) (in query: SELECT lgamma(NULL, NULL, NULL);) 2025.11.13 09:12:43.107076 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.130472 [ 18771 ] {9a40d409-21b4-4f5e-a96e-4b3261d6585a} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 803, line 804) (in query: SELECT like(NULL, NULL, NULL);) 2025.11.13 09:12:43.137615 [ 10137 ] {ee5c96f2-c8e0-416f-bb3d-a4e11a75ef9c} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:46468). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46468) (comment: 02784_parallel_replicas_automatic_decision.sh) (query 1, line 1) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_tg91tviv`.`test_parallel_replicas_automatic_count` AS `__table1` WHERE `__table1`.`number` < 500000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:1261: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed47b9 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:43.146360 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.158861 [ 10137 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:46468). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:1261: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed47b9 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:43.160637 [ 10181 ] {b4644478-8db2-443c-bd05-b25acf6af618} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1274, line 1277) (in query: SELECT subtractInterval(NULL, NULL, NULL);) 2025.11.13 09:12:43.169860 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.169970 [ 18771 ] {7b296c43-68e0-479a-80aa-a0db60b48f79} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 804, line 805) (in query: SELECT ln(NULL, NULL, NULL);) 2025.11.13 09:12:43.182910 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.207946 [ 17390 ] {812a74eb-1b95-47c0-84a8-650d68a8ae28} executeQuery: Code: 57. DB::Exception: Table test_z70ytfuh.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_zip.sh) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_z70ytfuh.`02661_archive_table` UUID '14a1cef6-5350-402b-ac3f-03696e5b8731' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_z70ytfuh_zip_archive{1..2}.zip :: 02661_read_from_archive_test_z70ytfuh_zip_data1.csv')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:43.216484 [ 17390 ] {812a74eb-1b95-47c0-84a8-650d68a8ae28} executeQuery: Code: 57. DB::Exception: Table test_z70ytfuh.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46184) (comment: 02661_read_from_archive_zip.sh) (query 1, line 1) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_z70ytfuh_zip_archive{1..2}.zip :: 02661_read_from_archive_test_z70ytfuh_zip_data1.csv')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:43.228494 [ 17390 ] {} TCPHandler: Code: 57. DB::Exception: Table test_z70ytfuh.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:43.244324 [ 18771 ] {b3d041dc-b20f-4295-bf6c-81c546eea593} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 806, line 807) (in query: SELECT log(NULL, NULL, NULL);) 2025.11.13 09:12:43.250543 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.272100 [ 18771 ] {892c1882-c0b2-4503-96fa-43cbcd792b3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 807, line 808) (in query: SELECT log10(NULL, NULL, NULL);) 2025.11.13 09:12:43.290182 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.313986 [ 18771 ] {f63cd3df-6671-4db8-b91a-3feb1be6b8d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 808, line 809) (in query: SELECT log1p(NULL, NULL, NULL);) 2025.11.13 09:12:43.320886 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.340890 [ 18771 ] {2afcd23d-8cc5-48d0-be39-17ceeb7476b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 809, line 810) (in query: SELECT log2(NULL, NULL, NULL);) 2025.11.13 09:12:43.346845 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.371983 [ 18771 ] {17e24dcc-f22d-474e-b06e-a7224702d260} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 810, line 811) (in query: SELECT logTrace(NULL, NULL, NULL);) 2025.11.13 09:12:43.383922 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.405404 [ 18771 ] {9c830b08-a479-457b-8d49-95cf3ef8f2bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 811, line 812) (in query: SELECT lowCardinalityIndices(NULL, NULL, NULL);) 2025.11.13 09:12:43.412881 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.441370 [ 18771 ] {0bb72c4e-0613-44f8-a762-c8f377e28f0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 812, line 813) (in query: SELECT lowCardinalityKeys(NULL, NULL, NULL);) 2025.11.13 09:12:43.450072 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.470288 [ 18771 ] {86257c2d-3615-40d2-9bc6-b29f4fcab2fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 813, line 814) (in query: SELECT lower(NULL, NULL, NULL);) 2025.11.13 09:12:43.486288 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.505532 [ 18771 ] {0ca82744-1ec7-4203-9e3c-09e4d21647c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 814, line 815) (in query: SELECT lowerUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:43.517678 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:43.587058 [ 10181 ] {88e0358e-9fae-4fd9-9029-5b67a5dc6647} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1282, line 1285) (in query: SELECT subtractTupleOfIntervals(NULL, NULL, NULL);) 2025.11.13 09:12:43.593963 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:44.207446 [ 18771 ] {fb83223e-b242-43bd-9333-cb61d071360e} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 822, line 824) (in query: SELECT map(NULL, NULL, NULL);) 2025.11.13 09:12:44.219460 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:44.267466 [ 17385 ] {67f3d2cf-5872-4d59-b2d2-231636c1c5aa} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 1, line 1) (in query: -- Related to https://github.com/ClickHouse/ClickHouse/issues/78088 -- Asserting that groupArray* function calls with zero `max_size` argument of -- different types (Int/UInt) will produce BAD_ARGUMENTS error SELECT groupArray(0::UInt64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.271753 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.298925 [ 17385 ] {0af1cf51-10d7-4286-86f2-257f435c411f} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 2, line 7) (in query: SELECT groupArray(0::Int64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.303338 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.355860 [ 17385 ] {1390f471-37eb-4be8-8e21-87e06a09f1c9} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 3, line 8) (in query: SELECT groupArray(0::UInt64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.360068 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.384227 [ 17385 ] {ed0b6182-e01b-40e8-b94a-597d7c33c30e} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 4, line 9) (in query: SELECT groupArray(0::Int64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.387999 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.417874 [ 17385 ] {dc731e6f-c5ba-410a-95fd-bee591d84a92} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 5, line 10) (in query: SELECT groupArray(0::UInt64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.425136 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.428719 [ 10181 ] {bf3112ba-7462-4f56-9f75-6c19cba8d17a} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1294, line 1297) (in query: SELECT synonyms(NULL, NULL, NULL);) 2025.11.13 09:12:44.437835 [ 10181 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:12:44.440154 [ 18771 ] {cdf2f5dd-9475-4ae9-8e0e-9b1bff44c5f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 827, line 829) (in query: SELECT mapContains(NULL, NULL, NULL);) 2025.11.13 09:12:44.452762 [ 17385 ] {620fe9df-bae1-4128-921e-410330b0ce99} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 6, line 11) (in query: SELECT groupArray(0::Int64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.454002 [ 10181 ] {d8dc3115-28f4-4117-a6ac-1decda7aedde} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1295, line 1298) (in query: SELECT tan(NULL, NULL, NULL);) 2025.11.13 09:12:44.456912 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020b9c04e 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:44.459711 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:44.464391 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:44.477125 [ 10181 ] {d0a576ac-75c6-4bc3-b573-b6a515ea2a6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1296, line 1299) (in query: SELECT tanh(NULL, NULL, NULL);) 2025.11.13 09:12:44.486705 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:44.502540 [ 10181 ] {71f83a79-8e52-42be-a81a-85ba5b747ac7} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1297, line 1300) (in query: SELECT tcpPort(NULL, NULL, NULL);) 2025.11.13 09:12:44.511125 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:44.527952 [ 10181 ] {e5482a8e-f3ea-4c32-b00f-20cf2fb0c2a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1298, line 1301) (in query: SELECT test_function(NULL, NULL, NULL);) 2025.11.13 09:12:44.532957 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:44.552993 [ 10181 ] {0951cbb0-aae0-48a0-874f-008f348515f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1299, line 1302) (in query: SELECT tgamma(NULL, NULL, NULL);) 2025.11.13 09:12:44.637997 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:44.857590 [ 10181 ] {bafe5327-77fb-4130-bc0c-7a8bb7fff11a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1302, line 1305) (in query: SELECT tid(NULL, NULL, NULL);) 2025.11.13 09:12:44.866692 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:44.889203 [ 10181 ] {d3494c75-21ba-42e2-8106-4a65efd1de71} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1303, line 1306) (in query: SELECT timeDiff(NULL, NULL, NULL);) 2025.11.13 09:12:44.898267 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.029231 [ 10181 ] {2d793a3a-61c5-4efd-89a8-b0d54c01c8b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1306, line 1309) (in query: SELECT timeZone(NULL, NULL, NULL);) 2025.11.13 09:12:45.040702 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.057702 [ 10181 ] {066cc7b3-d50d-4104-8608-6484e54dd962} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1307, line 1310) (in query: SELECT timeZoneOf(NULL, NULL, NULL);) 2025.11.13 09:12:45.066955 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.083433 [ 18771 ] {e5838ef7-ee22-4f28-9e29-37f8d7324820} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 832, line 834) (in query: SELECT mapFromArrays(NULL, NULL, NULL);) 2025.11.13 09:12:45.095181 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.176643 [ 18771 ] {6f8d2c35-d7ff-4bb9-a1a4-c0b578f35b91} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 834, line 836) (in query: SELECT mapKeys(NULL, NULL, NULL);) 2025.11.13 09:12:45.184919 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.416433 [ 18096 ] {c2399c02-cc2b-4bf2-88b9-fb6ffa4608e8} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46380) (comment: 02717_pretty_json.sql) (query 1, line 1) (in query: set allow_experimental_object_type=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.443730 [ 18096 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.444569 [ 10181 ] {f03e3d25-8ef3-43dc-b94a-ba655c939301} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1313, line 1316) (in query: SELECT timezone(NULL, NULL, NULL);) 2025.11.13 09:12:45.453957 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.474259 [ 10181 ] {b25d88a7-78d6-4413-a911-08cd2ba2c8e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1314, line 1317) (in query: SELECT timezoneOf(NULL, NULL, NULL);) 2025.11.13 09:12:45.496616 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.640269 [ 18391 ] {8c630d29-833c-4f60-b5b9-e903b3a3fd83} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'ttl' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02252_reset_non_existing_setting.sql) (in query: /* ddl_entry=query-0000000068 */ ALTER TABLE test_11.most_ordinary_mt (RESET SETTING ttl)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922b6d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.650383 [ 18391 ] {8c630d29-833c-4f60-b5b9-e903b3a3fd83} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'ttl' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46244) (comment: 02252_reset_non_existing_setting.sql) (query 3, line 10) (in query: ALTER TABLE most_ordinary_mt RESET SETTING ttl;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922b6d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.655883 [ 18391 ] {} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'ttl' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922b6d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.696875 [ 17385 ] {e601d99d-c778-4db0-9281-c8bbd15c3109} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 7, line 13) (in query: SELECT groupArraySorted(0::UInt64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.700944 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.728718 [ 17385 ] {6c600585-500c-496f-b7a1-5a393b503da1} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 8, line 14) (in query: SELECT groupArraySorted(0::Int64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.732744 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.758243 [ 17385 ] {f5f866f4-02d2-44a3-97a2-ce90c799498a} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 9, line 15) (in query: SELECT groupArraySorted(0::UInt64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.761930 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.785585 [ 17385 ] {30a602f0-b4cc-4300-ae31-880197248c25} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 10, line 16) (in query: SELECT groupArraySorted(0::Int64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.790389 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.809902 [ 18771 ] {6f60ef77-e606-4445-bd8b-2b8c7323f74a} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 841, line 843) (in query: SELECT mapUpdate(NULL, NULL, NULL);) 2025.11.13 09:12:45.819602 [ 17385 ] {3496d046-2cda-470f-9615-1f9102c13a1b} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 11, line 17) (in query: SELECT groupArraySorted(0::UInt64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.822444 [ 18391 ] {be16ea20-8195-402a-af43-9e68521ccca4} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'xxx' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02252_reset_non_existing_setting.sql) (in query: /* ddl_entry=query-0000000069 */ ALTER TABLE test_11.most_ordinary_mt (RESET SETTING allow_remote_fs_zero_copy_replication, xxx)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922b6d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.822670 [ 10181 ] {11f6b4aa-726f-455f-9a6b-5ba616f35c87} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1319, line 1322) (in query: SELECT toBool(NULL, NULL, NULL);) 2025.11.13 09:12:45.823788 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.825315 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.833628 [ 18391 ] {be16ea20-8195-402a-af43-9e68521ccca4} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'xxx' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46244) (comment: 02252_reset_non_existing_setting.sql) (query 4, line 11) (in query: ALTER TABLE most_ordinary_mt RESET SETTING allow_remote_fs_zero_copy_replication, xxx;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922b6d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.916107 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.918102 [ 18391 ] {} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'xxx' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922b6d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.937580 [ 17385 ] {59b53742-87a9-429d-862a-7bc031c6c5cc} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 12, line 18) (in query: SELECT groupArraySorted(0::Int64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.940484 [ 18771 ] {f3ce12a4-7fa2-499a-a776-8df648ec7cec} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 842, line 844) (in query: SELECT mapValues(NULL, NULL, NULL);) 2025.11.13 09:12:45.941766 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySorted should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArraySorted.cpp:409: DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020e7a23b 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:45.942193 [ 10181 ] {412f613e-3b2a-44bd-ab6d-db5f8d9f5d07} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1320, line 1323) (in query: SELECT toColumnTypeName(NULL, NULL, NULL);) 2025.11.13 09:12:45.946285 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.946787 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:45.981923 [ 18771 ] {4473c286-6b86-4970-b649-8a70440c94b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 843, line 845) (in query: SELECT match(NULL, NULL, NULL);) 2025.11.13 09:12:45.990318 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:46.021763 [ 18771 ] {8adcda45-0da5-46d0-828e-7fdf6933187b} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 844, line 846) (in query: SELECT materialize(NULL, NULL, NULL);) 2025.11.13 09:12:46.031254 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:46.078134 [ 10181 ] {da3c13fd-a89d-4292-9278-89242b9f1987} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1323, line 1326) (in query: SELECT toDate32OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:46.086882 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:46.176242 [ 18771 ] {b2d6576c-a4df-4659-a98b-dd25bc4366e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 846, line 848) (in query: SELECT max2(NULL, NULL, NULL);) 2025.11.13 09:12:46.182451 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:46.213402 [ 10181 ] {103df013-093b-48b8-85e4-9352c60b92bc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1326, line 1329) (in query: SELECT toDateOrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:46.220778 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:46.657191 [ 10181 ] {42ed47e1-29bf-41fa-b5cd-9595df53a3ee} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1332, line 1335) (in query: SELECT toDateTime64OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:46.667953 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:46.686297 [ 18732 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:46.686768 [ 18732 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:12:46.881459 [ 10181 ] {3f8b5c85-4535-400e-b585-7a8f21f8862e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1335, line 1338) (in query: SELECT toDateTimeOrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:46.891187 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:46.974549 [ 17385 ] {c091dd7a-5fe7-4565-ac43-b5352feb005e} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 13, line 20) (in query: SELECT groupArraySample(0::UInt64, 123)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:46.979476 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.011749 [ 17385 ] {4d54ffa2-8af4-42f1-af2b-5e6c33881b3f} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 14, line 21) (in query: SELECT groupArraySample(0::Int64, 123)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.015539 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.041436 [ 17385 ] {531e064e-c7db-42dc-8192-7d95784378ee} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 15, line 22) (in query: SELECT groupArraySample(0::UInt64, 123)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.048375 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.078854 [ 17385 ] {1314c1ae-2823-43fd-9c2b-32b8596a68aa} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 16, line 23) (in query: SELECT groupArraySample(0::Int64, 123)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.094920 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.183050 [ 17385 ] {db2bf394-5824-47f6-b74f-af7352afff84} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 17, line 24) (in query: SELECT groupArraySample(0::UInt64, 123)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.189043 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.231190 [ 17385 ] {96994ef1-91b1-4328-be9d-976a39bacf3f} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 18, line 25) (in query: SELECT groupArraySample(0::Int64, 123)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.235993 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArraySample should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:825: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)::$_0::operator()(unsigned long) const @ 0x0000000020bac370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:830: DB::(anonymous namespace)::createAggregateFunctionGroupArraySample(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba3a6c 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:12:47.598898 [ 10181 ] {bf2f278e-c2d9-4d2d-bc10-672bbd3cd6a3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1343, line 1346) (in query: SELECT toDecimal128OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:47.610460 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:47.954302 [ 10181 ] {84a4425f-2e17-4212-9292-0d9a6f3cddfe} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1347, line 1350) (in query: SELECT toDecimal256OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:47.959343 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:48.153604 [ 10181 ] {7164943d-07e5-4ede-94fe-51b158dd3ee0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1351, line 1354) (in query: SELECT toDecimal32OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:48.162109 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:48.209817 [ 18771 ] {dc831479-679a-4a6f-8864-f2d712bb74a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 870, line 872) (in query: SELECT min2(NULL, NULL, NULL);) 2025.11.13 09:12:48.215918 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.314800 [ 18771 ] {1d4032a1-5745-40a2-9529-811010e036f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 872, line 874) (in query: SELECT minSampleSizeContinous(NULL, NULL, NULL);) 2025.11.13 09:12:48.326052 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.330960 [ 10181 ] {2b731176-95ad-4a18-b1a4-ee773b41b932} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1355, line 1358) (in query: SELECT toDecimal64OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:48.338248 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:48.348700 [ 18771 ] {12a2f991-caf8-46e7-8e47-ff7208777e8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 873, line 875) (in query: SELECT minSampleSizeContinuous(NULL, NULL, NULL);) 2025.11.13 09:12:48.355591 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.378468 [ 18771 ] {ee9d4740-2af4-4ed9-a726-b4b85b6b69bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 874, line 876) (in query: SELECT minSampleSizeConversion(NULL, NULL, NULL);) 2025.11.13 09:12:48.389888 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.471763 [ 18772 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.471880 [ 18771 ] {34919fe3-6b80-4612-ad00-9d3799d3fc05} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 875, line 877) (in query: SELECT minus(NULL, NULL, NULL);) 2025.11.13 09:12:48.472484 [ 18772 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.481026 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.498848 [ 18771 ] {39d74a79-feb7-4c38-9460-7cc0b9f7abaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 876, line 878) (in query: SELECT mismatches(NULL, NULL, NULL);) 2025.11.13 09:12:48.505717 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.530565 [ 18771 ] {da125380-dee9-43de-8539-aedada90e1d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 877, line 879) (in query: SELECT mod(NULL, NULL, NULL);) 2025.11.13 09:12:48.536315 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.583992 [ 18771 ] {8c16542f-eefa-4eaa-8039-635643e879ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 878, line 880) (in query: SELECT modulo(NULL, NULL, NULL);) 2025.11.13 09:12:48.598075 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.599884 [ 10181 ] {83297b1e-7594-4deb-9b4f-845a0b0763e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1358, line 1361) (in query: SELECT toDecimalString(NULL, NULL, NULL);) 2025.11.13 09:12:48.604778 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.618604 [ 18771 ] {3ffde1c3-3942-4e1f-8f27-2b3571016210} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 879, line 881) (in query: SELECT moduloLegacy(NULL, NULL, NULL);) 2025.11.13 09:12:48.630493 [ 17385 ] {0959bb46-bf30-4164-aca6-d90b5ed988cc} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 19, line 27) (in query: SELECT groupArrayLast(0::UInt64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.633946 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.634298 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.657564 [ 18771 ] {6602348f-d8c4-4d40-b333-be0dfaa6bd90} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 880, line 882) (in query: SELECT moduloOrZero(NULL, NULL, NULL);) 2025.11.13 09:12:48.662213 [ 17385 ] {f9938597-1f1b-4d26-8acc-007465ee585c} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 20, line 28) (in query: SELECT groupArrayLast(0::Int64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.663435 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.668424 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.714363 [ 10181 ] {e35c412d-85f7-4669-a69e-83dc92399159} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1359, line 1362) (in query: SELECT toFixedString(NULL, NULL, NULL);) 2025.11.13 09:12:48.727277 [ 17385 ] {9014b3e2-87fb-434c-a368-dbc04c43e4cc} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 21, line 29) (in query: SELECT groupArrayLast(0::UInt64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.733064 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.737387 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.783620 [ 17385 ] {2e745d9f-c2f1-4b2d-8109-ab4554dd4971} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 22, line 30) (in query: SELECT groupArrayLast(0::Int64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.787566 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.802876 [ 10181 ] {b76543b1-5f02-4c97-8790-eb5bb1fdb3cf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1361, line 1364) (in query: SELECT toFloat32OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:48.810069 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.817742 [ 17385 ] {dc8c19bd-ca40-4b47-9b75-9a193dd01791} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 23, line 31) (in query: SELECT groupArrayLast(0::UInt64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.822122 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.857753 [ 17385 ] {c3416e9c-0a54-4f86-a0f3-668290a0a0bd} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 24, line 32) (in query: SELECT groupArrayLast(0::Int64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.859319 [ 18771 ] {5c110257-b8bb-4974-8666-bc327baec743} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 881, line 883) (in query: SELECT monthName(NULL, NULL, NULL);) 2025.11.13 09:12:48.862399 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayLast should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:789: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionGroupArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020ba8008 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:48.874213 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:48.893281 [ 18771 ] {8aa63921-8b3e-4412-bd33-e4ba882f8241} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 882, line 884) (in query: SELECT mortonDecode(NULL, NULL, NULL);) 2025.11.13 09:12:48.898832 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.176853 [ 10181 ] {db2ac095-44e8-4a77-a573-5d5d8dfbdba5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1365, line 1368) (in query: SELECT toFloat64OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:49.186043 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.283485 [ 18771 ] {a6eb9eb0-1550-463d-94d3-5ede6a6c1ab4} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 888, line 890) (in query: SELECT multiMatchAllIndices(NULL, NULL, NULL);) 2025.11.13 09:12:49.290449 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.318076 [ 18771 ] {f9a90165-2394-4db1-9761-1cafb6bcbd4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 889, line 891) (in query: SELECT multiMatchAny(NULL, NULL, NULL);) 2025.11.13 09:12:49.327621 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.352721 [ 18771 ] {1cea4d14-9419-4f99-b398-a83c52ef5be4} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 890, line 892) (in query: SELECT multiMatchAnyIndex(NULL, NULL, NULL);) 2025.11.13 09:12:49.360815 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.443107 [ 18771 ] {53c549b0-a763-4c98-a88b-8e0d5a83f5e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 891, line 893) (in query: SELECT multiSearchAllPositions(NULL, NULL, NULL);) 2025.11.13 09:12:49.458906 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.565657 [ 18771 ] {4b57c3ad-b565-4be6-ba2f-dc0684811fa7} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 892, line 894) (in query: SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:49.575381 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.614816 [ 18771 ] {3582eb15-eb44-443b-b966-e935b89887b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 893, line 895) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:49.621917 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.645628 [ 18771 ] {43eff528-731a-492d-b232-12f78ac3f95c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 894, line 896) (in query: SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:49.655746 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.680532 [ 18771 ] {e1271be3-f611-4557-ae27-13e55e98ad01} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 895, line 897) (in query: SELECT multiSearchAny(NULL, NULL, NULL);) 2025.11.13 09:12:49.689734 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.712120 [ 18771 ] {2ae48c58-25e3-47bb-92ca-b7e5c739a9b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 896, line 898) (in query: SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:49.717195 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.741966 [ 18771 ] {6875cf09-1f9d-4c5b-881d-f6b7cc4f05d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 897, line 899) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:49.748787 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.791658 [ 18771 ] {d51656da-30b7-4d32-a61f-3af1302ee974} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 898, line 900) (in query: SELECT multiSearchAnyUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:49.799404 [ 10181 ] {07e96065-23aa-484c-8f8d-77febb24651e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1370, line 1373) (in query: SELECT toIPv4OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:49.801982 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.813396 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.826456 [ 18771 ] {fd488cec-8ff2-4762-aedc-c9d2a2923ebb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 899, line 901) (in query: SELECT multiSearchFirstIndex(NULL, NULL, NULL);) 2025.11.13 09:12:49.835589 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.919173 [ 18771 ] {46eabf97-78db-47d4-bdd5-1700e293ccba} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 900, line 902) (in query: SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:49.924340 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.947413 [ 18771 ] {2938c684-56b8-4ca5-aeaf-0e4e8801b373} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 901, line 903) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:49.953609 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.979320 [ 18771 ] {4ad6455d-1135-4d9a-8b10-6b38ba2a37a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 902, line 904) (in query: SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:49.985004 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:49.992862 [ 10181 ] {eb2fb90e-be4a-45a2-970c-046fc490ea62} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1374, line 1377) (in query: SELECT toIPv6OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:49.998248 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:50.010863 [ 18771 ] {87188b6a-88d8-484e-a7a4-30cc1b09f7ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 903, line 905) (in query: SELECT multiSearchFirstPosition(NULL, NULL, NULL);) 2025.11.13 09:12:50.017301 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:50.125029 [ 18771 ] {42cfd39a-ce27-4064-a420-47ca7d1543bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 904, line 906) (in query: SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:50.130309 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:50.159196 [ 18771 ] {be8b99bf-a3f1-4852-977e-c64a5f2c290e} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 905, line 907) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:50.164905 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:50.188916 [ 18771 ] {934fbc4b-b9e4-48db-a344-15a4885bafc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 906, line 908) (in query: SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:50.197016 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:50.200474 [ 18772 ] {67bb9acd-ba53-49e9-bd9a-9b142fd7f10d} executeQuery: Code: 60. DB::Exception: Table test_detvkreu.ghdata_2 does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46560) (comment: 01825_type_json_ghdata_insert_select.sh) (query 1, line 1) (in query: INSERT INTO ghdata_2 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.206533 [ 18772 ] {} TCPHandler: Code: 60. DB::Exception: Table test_detvkreu.ghdata_2 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.269222 [ 18771 ] {1a50aec1-6283-4794-952c-b5349e1be28c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 907, line 909) (in query: SELECT multiply(NULL, NULL, NULL);) 2025.11.13 09:12:50.274482 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:50.387192 [ 17385 ] {8610de3f-f9d0-42a6-b3cb-e4dc53d0905a} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 25, line 34) (in query: SELECT groupArrayMovingSum(0::UInt64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.391051 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.400029 [ 17226 ] {96362405-9e0c-472d-802e-68c7a97dd261} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 10028.573217 ms, maximum: 10000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36112) (comment: 01249_flush_interactive.sh) (in query: SELECT DISTINCT number % 5 FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.432627 [ 17226 ] {96362405-9e0c-472d-802e-68c7a97dd261} DynamicQueryHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 10028.573217 ms, maximum: 10000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:50.438272 [ 17385 ] {e867ab2a-586e-4ed1-aaa5-7562ac1a187b} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 26, line 35) (in query: SELECT groupArrayMovingSum(0::Int64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.453328 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.482346 [ 17385 ] {78ab9f43-5fb7-4912-ba8d-383dce923375} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 27, line 36) (in query: SELECT groupArrayMovingSum(0::UInt64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.495709 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.497858 [ 10181 ] {3ae695ca-c8b9-4282-89f3-c7603d360e4b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1380, line 1383) (in query: SELECT toInt128OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:50.506223 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:50.529898 [ 17385 ] {e4076eda-4ce5-4359-9bf7-23b54b830fe3} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 28, line 37) (in query: SELECT groupArrayMovingSum(0::Int64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.534170 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.567904 [ 17385 ] {405c466e-c0ca-4b13-bd04-6ea8e007df84} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 29, line 38) (in query: SELECT groupArrayMovingSum(0::UInt64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.577777 [ 18824 ] {a3627e4e-6534-4259-9118-bfe0135c13a3} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46572) (comment: 01093_cyclic_defaults_filimonov.sql) (query 1, line 1) (in query: CREATE TABLE test ( `a0` UInt64 DEFAULT a1 + 1, `a1` UInt64 DEFAULT a0 + 1, `a2` UInt64 DEFAULT a3 + a4, `a3` UInt64 DEFAULT a2 + 1, `a4` UInt64 ALIAS a3 + 1 ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033712acd 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 19. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 20. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 21. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 22. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:12:50.583746 [ 18824 ] {} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033712acd 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 19. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 20. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 21. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 22. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:12:50.601911 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.642723 [ 17385 ] {56d71da5-e41a-4db9-a482-01e30ef49bcd} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 30, line 39) (in query: SELECT groupArrayMovingSum(0::Int64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.666992 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:50.783932 [ 10181 ] {1b9774fd-2573-4565-98ce-287b89964669} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1384, line 1387) (in query: SELECT toInt16OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:50.824980 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:50.901014 [ 18771 ] {eda6dd6d-831f-4876-828a-6ad38ef4d000} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 914, line 916) (in query: SELECT negate(NULL, NULL, NULL);) 2025.11.13 09:12:50.914036 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:51.041213 [ 10181 ] {790d20f2-d0f1-4412-9f53-d5f5348b658c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1388, line 1391) (in query: SELECT toInt256OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:51.051560 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:51.177926 [ 18771 ] {2892d7e7-8970-4b31-8eb4-7e1cd37f5913} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 915, line 917) (in query: SELECT neighbor(NULL, NULL, NULL);) 2025.11.13 09:12:51.183466 [ 18771 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:12:51.247553 [ 17226 ] {96362405-9e0c-472d-802e-68c7a97dd261} bool DB::WriteBufferFromHTTPServerResponse::cancelWithException(HTTPServerRequest &, int, const std::string &, WriteBuffer *): Failed to send exception to the response write buffer.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:36112). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./src/Server/HTTP/HTTPServerResponse.h:197: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000003af4d2f4 5. ./src/Server/HTTP/HTTPServerResponse.h:166: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003af464df 6. DB::WriteBuffer::next() @ 0x0000000008c37ea1 7. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:355: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000003af48d63 8. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace747b 9. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:12:51.275360 [ 10181 ] {84243899-1be4-42b0-a56a-9cae3211253f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1392, line 1395) (in query: SELECT toInt32OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:51.280895 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:51.337469 [ 18771 ] {6b0bfa64-144f-4aee-94a8-a1e8323d9510} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 917, line 919) (in query: SELECT netloc(NULL, NULL, NULL);) 2025.11.13 09:12:51.343929 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:51.369563 [ 18771 ] {1543f4a1-af33-46a7-9eb9-a288fc97b83c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 918, line 920) (in query: SELECT ngramDistance(NULL, NULL, NULL);) 2025.11.13 09:12:51.381952 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:51.396776 [ 18771 ] {542ec56c-22a3-462e-94e6-e46f8d8b2fd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 919, line 921) (in query: SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:51.407987 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:51.429380 [ 18771 ] {90a2778e-b6c8-4789-b86c-ab5186903fe0} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 920, line 922) (in query: SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:51.434369 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:51.445395 [ 10181 ] {7851ccf4-2eb6-4f28-9cce-f4a43589d9e8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1396, line 1399) (in query: SELECT toInt64OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:51.451673 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:51.457264 [ 18771 ] {87152329-d174-406e-8460-b059a9328ca2} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 921, line 923) (in query: SELECT ngramDistanceUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:51.465686 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:51.615481 [ 18824 ] {15c259db-965a-4418-9b8e-e9a79c44d00f} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46572) (comment: 01093_cyclic_defaults_filimonov.sql) (query 2, line 11) (in query: CREATE TABLE pythagoras ( `a` Float64 DEFAULT sqrt((c * c) - (b * b)), `b` Float64 DEFAULT sqrt((c * c) - (a * a)), `c` Float64 DEFAULT sqrt((a * a) + (b * b)) ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033712acd 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 20. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 21. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 22. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 23. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 24. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 25. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 26. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 27. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 29. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 30. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 2025.11.13 09:12:51.670172 [ 18824 ] {} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033712acd 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 20. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 21. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 22. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 23. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 24. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 25. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 26. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 27. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 29. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 30. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 2025.11.13 09:12:51.739193 [ 10181 ] {6fadf7e1-3c16-4589-8fce-85ae790f70aa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1400, line 1403) (in query: SELECT toInt8OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:51.770006 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:51.965127 [ 17385 ] {fc5e1e9e-a7ce-4cba-b1ec-30fe6e81527c} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 31, line 41) (in query: SELECT groupArrayMovingAvg(0::UInt64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:51.968873 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.038076 [ 17385 ] {f4ee2376-62ca-41cb-97b1-96f33a0c7f28} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 32, line 42) (in query: SELECT groupArrayMovingAvg(0::Int64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.044036 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.093156 [ 16889 ] {0c155b22-31b0-427d-b475-8d90e290545e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46604) (comment: 01033_function_substring.sql) (query 2, line 3) (in query: SELECT substring('hello', []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a771f13 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:52.097519 [ 16889 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a771f13 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:52.174500 [ 17385 ] {5d776642-7366-45cd-a6a6-84de31da23b8} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 33, line 43) (in query: SELECT groupArrayMovingAvg(0::UInt64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.178198 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.193138 [ 18771 ] {b119b100-61ee-4f4b-8eb9-bd1b32be39e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 930, line 932) (in query: SELECT ngramSearch(NULL, NULL, NULL);) 2025.11.13 09:12:52.198796 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.224295 [ 18771 ] {8068b7f1-2170-49da-b20d-af107f53ec4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 931, line 933) (in query: SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL);) 2025.11.13 09:12:52.229837 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.252403 [ 18771 ] {e0a24d99-5015-4318-b0f6-5cce5e875e7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 932, line 934) (in query: SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:52.264237 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.299319 [ 18771 ] {31f12ef1-eaf7-4328-8f28-225389f80361} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 933, line 935) (in query: SELECT ngramSearchUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:52.299322 [ 17385 ] {8a5e58d0-24be-4d6e-acaa-a1ddcfe60f0b} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 34, line 44) (in query: SELECT groupArrayMovingAvg(0::Int64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.303197 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.308472 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.339202 [ 17385 ] {0677bb4a-1cad-4a86-a4c1-34607e3bf4c4} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 35, line 45) (in query: SELECT groupArrayMovingAvg(0::UInt64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.344064 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.377430 [ 17385 ] {4c6ee67d-ccfd-4797-81aa-0ce65cdf4b58} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 36, line 46) (in query: SELECT groupArrayMovingAvg(0::Int64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.382391 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingAvg should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a44766 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:52.546693 [ 10181 ] {8d1a4dcc-4334-4e32-a0ac-b71f437c7bf0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1414, line 1417) (in query: SELECT toJSONString(NULL, NULL, NULL);) 2025.11.13 09:12:52.555327 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.623780 [ 18771 ] {83996492-f692-4025-abd8-c58a97ad45d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 938, line 940) (in query: SELECT ngrams(NULL, NULL, NULL);) 2025.11.13 09:12:52.645542 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.664322 [ 18771 ] {ebdcf6fe-9175-490d-9550-44c92f42ec15} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 939, line 941) (in query: SELECT nonNegativeDerivative(NULL, NULL, NULL);) 2025.11.13 09:12:52.673924 [ 10181 ] {c5d2fd75-000b-41b1-bba8-b82793f5845d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1417, line 1420) (in query: SELECT toLowCardinality(NULL, NULL, NULL);) 2025.11.13 09:12:52.673892 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Nullable(Nothing)' given. (BAD_ARGUMENTS) 2025.11.13 09:12:52.682462 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.694505 [ 18771 ] {bb9fd009-5690-4b7e-91fd-3c90bce43b25} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 940, line 942) (in query: SELECT normL1(NULL, NULL, NULL);) 2025.11.13 09:12:52.702149 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.723849 [ 18771 ] {f845be33-b79e-499c-ba80-ea26ba6bd93d} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 941, line 943) (in query: SELECT normL2(NULL, NULL, NULL);) 2025.11.13 09:12:52.733162 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.765972 [ 18771 ] {d076fe38-34a7-4896-8fec-85ebaf4a7352} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 942, line 944) (in query: SELECT normL2Squared(NULL, NULL, NULL);) 2025.11.13 09:12:52.773142 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.796741 [ 10181 ] {1fb4d04f-6d7e-4c0e-b6ae-8dca9a29636e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1420, line 1423) (in query: SELECT toModifiedJulianDay(NULL, NULL, NULL);) 2025.11.13 09:12:52.805207 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.824934 [ 10181 ] {cc39c247-e5e0-4ff7-91b5-73862f0cddb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1421, line 1424) (in query: SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:52.830988 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:52.862860 [ 18771 ] {31eadba1-5fec-490f-82ed-2d8803dad24e} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 943, line 945) (in query: SELECT normLinf(NULL, NULL, NULL);) 2025.11.13 09:12:52.870225 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.035529 [ 18771 ] {c59bc431-6497-4c79-8f87-441f58f005f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 944, line 946) (in query: SELECT normLp(NULL, NULL, NULL);) 2025.11.13 09:12:53.049448 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.069859 [ 18771 ] {b8cd8e0b-42b5-42a7-9ad7-26b06441eee5} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 945, line 947) (in query: SELECT normalizeL1(NULL, NULL, NULL);) 2025.11.13 09:12:53.083514 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.104928 [ 18771 ] {9a9bf139-502d-48fc-9b55-079ba685afa7} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 946, line 948) (in query: SELECT normalizeL2(NULL, NULL, NULL);) 2025.11.13 09:12:53.105741 [ 10181 ] {51ef3905-e82d-4b2e-b013-a605a3fbe3bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1425, line 1428) (in query: SELECT toNullable(NULL, NULL, NULL);) 2025.11.13 09:12:53.112986 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.143864 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.170652 [ 18771 ] {b0f60e2a-5069-4d83-af7c-8e7c6c28a484} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 947, line 949) (in query: SELECT normalizeLinf(NULL, NULL, NULL);) 2025.11.13 09:12:53.178222 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.184283 [ 16703 ] {60637e43-b454-4ae5-a56d-5ee7cdd83232} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39954) (comment: 01560_cancel_agg_func_combinator_native_name_constraint.sql) (query 4, line 4) (in query: SELECT SUMOrNullIf(1, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:12:53.194855 [ 16703 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:53.221733 [ 16207 ] {6607ad7a-a0c0-4bcf-b664-7de57931dd85} executeQuery: Code: 60. DB::Exception: Table test_detvkreu.ghdata_2_from_string does not exist. Maybe you meant test_detvkreu.ghdata_2_string?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39958) (comment: 01825_type_json_ghdata_insert_select.sh) (query 1, line 1) (in query: INSERT INTO ghdata_2_from_string SELECT data FROM ghdata_2_string), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:53.230775 [ 16207 ] {} TCPHandler: Code: 60. DB::Exception: Table test_detvkreu.ghdata_2_from_string does not exist. Maybe you meant test_detvkreu.ghdata_2_string?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:53.270869 [ 18771 ] {724857ec-1c66-4331-b78c-05baf3eee057} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 948, line 950) (in query: SELECT normalizeLp(NULL, NULL, NULL);) 2025.11.13 09:12:53.285165 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.304543 [ 18771 ] {f24b0ff7-68ed-4fd7-af53-53bd2844da7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 949, line 951) (in query: SELECT normalizeQuery(NULL, NULL, NULL);) 2025.11.13 09:12:53.316604 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.340205 [ 18771 ] {ec0f13bc-a7c2-4396-9472-d46232310b37} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 950, line 952) (in query: SELECT normalizeQueryKeepNames(NULL, NULL, NULL);) 2025.11.13 09:12:53.351173 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.385932 [ 18771 ] {65521c9c-ed1b-4130-846f-c281ccc686c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 951, line 953) (in query: SELECT normalizeUTF8NFC(NULL, NULL, NULL);) 2025.11.13 09:12:53.391677 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.482657 [ 18771 ] {1e45899c-7ddb-488c-9d58-db499befd498} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 952, line 954) (in query: SELECT normalizeUTF8NFD(NULL, NULL, NULL);) 2025.11.13 09:12:53.494748 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.610645 [ 18771 ] {5ac08a22-5960-4fdd-a41e-358f4533831e} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 953, line 955) (in query: SELECT normalizeUTF8NFKC(NULL, NULL, NULL);) 2025.11.13 09:12:53.617781 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.661460 [ 16889 ] {3f5d7754-3063-4598-840d-b724eecb36f6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', 1, []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46604) (comment: 01033_function_substring.sql) (query 3, line 4) (in query: SELECT substring('hello', 1, []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a772426 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:53.744127 [ 16889 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of function substring, expected (U)Int*: In scope SELECT substring('hello', 1, []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::(anonymous namespace)::FunctionSubstring::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a772426 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:12:53.750643 [ 18771 ] {d1813ee2-bd87-4891-84f8-3e618bc446f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 954, line 956) (in query: SELECT normalizeUTF8NFKD(NULL, NULL, NULL);) 2025.11.13 09:12:53.765410 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.826683 [ 18771 ] {4a03928b-558c-4b6d-b716-936e6cd5ddbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 955, line 957) (in query: SELECT normalizedQueryHash(NULL, NULL, NULL);) 2025.11.13 09:12:53.840772 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.861355 [ 18771 ] {68bf656f-7b7d-4595-bc75-e34140c607ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 956, line 958) (in query: SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL);) 2025.11.13 09:12:53.868926 [ 17385 ] {acc3af50-84e0-49b8-9de4-6b1493ed72e3} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 37, line 48) (in query: SELECT groupUniqArray(0::UInt64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:53.872397 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:53.877874 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.895353 [ 18771 ] {51836491-83ac-40a5-805a-f751bb65a5f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 957, line 959) (in query: SELECT not(NULL, NULL, NULL);) 2025.11.13 09:12:53.907346 [ 17385 ] {0ee525d2-8e71-461b-b7ea-e5dddeb74c86} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 38, line 49) (in query: SELECT groupUniqArray(0::Int64)(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:53.910004 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.913567 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:53.935024 [ 18771 ] {1b336909-f40b-45c9-bd48-5a7c95132c5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 958, line 960) (in query: SELECT notEmpty(NULL, NULL, NULL);) 2025.11.13 09:12:53.946122 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.976793 [ 18771 ] {8cb3232b-27c8-4b70-a8dd-0d49e619716c} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 959, line 961) (in query: SELECT notEquals(NULL, NULL, NULL);) 2025.11.13 09:12:53.981663 [ 17385 ] {c6fd218b-ce69-467e-8042-9e2dad06fc65} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 39, line 50) (in query: SELECT groupUniqArray(0::UInt64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:53.982434 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:53.986679 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:54.012456 [ 18771 ] {ee4faa8e-951f-42d8-ad3c-7e088d337fac} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 960, line 962) (in query: SELECT notILike(NULL, NULL, NULL);) 2025.11.13 09:12:54.021220 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.030320 [ 17385 ] {4087f5e3-39a8-4660-8caa-c514c1599004} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 40, line 51) (in query: SELECT groupUniqArray(0::Int64)('x');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:54.035801 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:54.054906 [ 18771 ] {aee2d37b-4def-4b1c-a38d-c11276cc5962} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 961, line 963) (in query: SELECT notIn(NULL, NULL, NULL);) 2025.11.13 09:12:54.062283 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.083946 [ 18771 ] {ee739292-7588-4d2a-b255-bd5fbdd24a3e} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 962, line 964) (in query: SELECT notInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:54.169290 [ 17385 ] {9ecb5957-db4b-47ef-9634-b12f211cbf7c} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 41, line 52) (in query: SELECT groupUniqArray(0::UInt64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:54.171604 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.173806 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:54.199224 [ 18771 ] {906a1f59-5d36-4283-b9a7-2f01af88bef7} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 963, line 965) (in query: SELECT notLike(NULL, NULL, NULL);) 2025.11.13 09:12:54.211215 [ 17385 ] {ab89a521-8cfc-4dcc-9a4c-f2fc57cffcaa} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46230) (comment: 03398_group_array_zero_max_elements.sql) (query 42, line 53) (in query: SELECT groupUniqArray(0::Int64)(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:54.212416 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.215860 [ 17385 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupUniqArray should be positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupUniqArray.cpp:327: DB::(anonymous namespace)::createAggregateFunctionGroupUniqArray(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000210d209c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:54.230414 [ 18771 ] {f5435e52-790a-4100-9b64-4e0567b2542c} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 964, line 966) (in query: SELECT notNullIn(NULL, NULL, NULL);) 2025.11.13 09:12:54.238745 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.259325 [ 18771 ] {81544831-51a3-4ed9-8fdf-60dc4a081e5f} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 965, line 967) (in query: SELECT notNullInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:54.269522 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.493330 [ 18771 ] {9f19e7d8-f565-4219-ac73-1d33ea5e81f6} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 969, line 971) (in query: SELECT now(NULL, NULL, NULL);) 2025.11.13 09:12:54.499290 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.667768 [ 18771 ] {768000f9-6dbf-405c-bda2-431ec062a5eb} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 972, line 974) (in query: SELECT nth_value(NULL, NULL, NULL);) 2025.11.13 09:12:54.678140 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.694502 [ 18771 ] {e90e0ab8-68a3-4a5b-bb40-3f1afcf7a324} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 973, line 975) (in query: SELECT ntile(NULL, NULL, NULL);) 2025.11.13 09:12:54.703621 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.721574 [ 18771 ] {81aaabdf-3091-42e2-a3c8-8023b1b5d5b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 974, line 976) (in query: SELECT nullIf(NULL, NULL, NULL);) 2025.11.13 09:12:54.726442 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.748780 [ 18771 ] {14b59b64-2492-4885-97dc-6c16f6ab1eb9} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 975, line 977) (in query: SELECT nullIn(NULL, NULL, NULL);) 2025.11.13 09:12:54.762777 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:54.781844 [ 18771 ] {c2333284-c121-442c-9d40-ed9fd39f9acb} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 976, line 978) (in query: SELECT nullInIgnoreSet(NULL, NULL, NULL);) 2025.11.13 09:12:54.789107 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:55.162996 [ 18131 ] {48e08451-5bbc-41f3-a43f-504be365b403} executeQuery: Code: 57. DB::Exception: Table test_z70ytfuh.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02661_read_from_archive_zip.sh) (in query: /* ddl_entry=query-0000000008 */ CREATE TABLE test_z70ytfuh.`02661_archive_table` UUID 'c57c17b1-6d94-4456-8aa9-fa77be8d68e5' ENGINE = File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_z70ytfuh_zip_archive3.zip :: 02661_read_from_archive_test_z70ytfuh_zip_data*.csv')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:55.170904 [ 18131 ] {48e08451-5bbc-41f3-a43f-504be365b403} executeQuery: Code: 57. DB::Exception: Table test_z70ytfuh.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40052) (comment: 02661_read_from_archive_zip.sh) (query 1, line 1) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_z70ytfuh_zip_archive3.zip :: 02661_read_from_archive_test_z70ytfuh_zip_data*.csv')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:55.177512 [ 18131 ] {} TCPHandler: Code: 57. DB::Exception: Table test_z70ytfuh.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:12:55.378871 [ 16207 ] {d7d1566e-1568-426e-8a4c-963a10321a81} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39992) (comment: 01593_insert_settings.sql) (query 4, line 5) (in query: insert into data_01593 select * from numbers_mt(10) settings max_partitions_per_insert_block=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:119: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7dcd5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:12:55.388165 [ 16207 ] {} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:119: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7dcd5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:12:55.448208 [ 3897 ] {6f8f1d5b-cb1d-4cba-aac8-1696205b2d32} MergeTreeDataWriter: INSERT query from initial_user default (query ID: 6f8f1d5b-cb1d-4cba-aac8-1696205b2d32) inserted a block that created parts in 10 partitions. This is being logged rather than throwing an exception as throw_on_max_partitions_per_insert_block=false. 2025.11.13 09:12:55.489570 [ 10181 ] {5b9f4f74-e872-4cb7-8eee-7b031ef8d2b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1454, line 1457) (in query: SELECT toStringCutToZero(NULL, NULL, NULL);) 2025.11.13 09:12:55.497871 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:55.522031 [ 16889 ] {cd279017-6902-461d-80b1-98a564715572} executeQuery: Code: 135. DB::Exception: Indices in strings are 1-based. (ZERO_ARRAY_OR_TUPLE_INDEX) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46604) (comment: 01033_function_substring.sql) (query 5, line 6) (in query: SELECT substring(materialize('hello'), 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionSubstring::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a76ffe5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:12:55.539636 [ 16889 ] {} TCPHandler: Code: 135. DB::Exception: Indices in strings are 1-based. (ZERO_ARRAY_OR_TUPLE_INDEX), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionSubstring::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a76ffe5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:12:55.559301 [ 10181 ] {03822067-184e-4a33-83d4-a5e03dbaaf32} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1456, line 1459) (in query: SELECT toTimeZone(NULL, NULL, NULL);) 2025.11.13 09:12:55.566639 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:55.582793 [ 10181 ] {0b10a93b-2924-4b07-8334-713194320a17} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1457, line 1460) (in query: SELECT toTimezone(NULL, NULL, NULL);) 2025.11.13 09:12:55.588561 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:55.605009 [ 10181 ] {ab51f8ff-e16b-4e42-9ddb-98bd40cf0ae2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1458, line 1461) (in query: SELECT toTypeName(NULL, NULL, NULL);) 2025.11.13 09:12:55.612952 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:55.726392 [ 10181 ] {6e939e8b-33b9-4032-9b65-e5c88dafe5dc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1460, line 1463) (in query: SELECT toUInt128OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:55.764166 [ 16605 ] {9f144187-08e5-460d-ba53-38335b1c4317} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata_2_from_string' in scope (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2_from_string). (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40028) (comment: 01825_type_json_ghdata_insert_select.sh) (query 1, line 1) (in query: SELECT (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2_from_string) = (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:55.772327 [ 16605 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata_2_from_string' in scope (SELECT toTypeName(any(data)), sum(cityHash64(flattenTuple(data))) FROM ghdata_2_from_string). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:12:55.774800 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:55.816959 [ 16375 ] {a131dbdb-9084-4e2d-b2fb-89d942aeab02} executeQuery: Code: 191. DB::Exception: Limit for JOIN exceeded, max rows: 1.00 thousand, current rows: 4.00 thousand: While executing FillingRightJoinSide. (SET_SIZE_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40024) (comment: 01010_pmj_on_disk.sql) (query 4, line 13) (in query: SELECT n, j FROM (SELECT number AS n FROM numbers(4)) nums ANY LEFT JOIN ( SELECT number * 2 AS n, number + 10 AS j FROM numbers(4000) ) js2 USING n ORDER BY n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:767: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x0000000033bd884d 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:553: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x0000000033bcba85 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x000000003bb38b58 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:12:55.828926 [ 16375 ] {} TCPHandler: Code: 191. DB::Exception: Limit for JOIN exceeded, max rows: 1.00 thousand, current rows: 4.00 thousand: While executing FillingRightJoinSide. (SET_SIZE_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:767: DB::HashJoin::addBlockToJoin(DB::ScatteredBlock&, bool) @ 0x0000000033bd884d 7. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:553: DB::HashJoin::addBlockToJoin(DB::Block const&, bool) @ 0x0000000033bcba85 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:357: DB::FillingRightJoinSideTransform::work() @ 0x000000003bb38b58 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:12:56.090587 [ 10181 ] {387d1fe4-0bbd-4a4f-a828-d1fe9b629385} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1464, line 1467) (in query: SELECT toUInt16OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:56.099728 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:56.462225 [ 10181 ] {89f6b0a8-06a0-40fe-af43-0f5e6b32eac5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1468, line 1471) (in query: SELECT toUInt256OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:56.469569 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:56.702256 [ 10181 ] {5961feb3-0424-4414-8dda-65d253dbad75} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1472, line 1475) (in query: SELECT toUInt32OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:56.707877 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:57.035518 [ 10181 ] {947234f8-a046-4fcf-ae29-2ee6f86b4233} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1476, line 1479) (in query: SELECT toUInt64OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:57.144292 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:57.367311 [ 18771 ] {99d7bd8d-cd72-4587-9e94-5079dc19edc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1007, line 1009) (in query: SELECT parseReadableSize(NULL, NULL, NULL);) 2025.11.13 09:12:57.382123 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:57.413128 [ 18771 ] {df3da146-1383-4570-8a69-c90f923adf9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1008, line 1010) (in query: SELECT parseReadableSizeOrNull(NULL, NULL, NULL);) 2025.11.13 09:12:57.421756 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:57.501276 [ 10181 ] {b46bc110-77e6-4d82-9f98-b0da95bd0e0c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1480, line 1483) (in query: SELECT toUInt8OrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:57.516578 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:57.528584 [ 18771 ] {ea62d094-f324-4711-bf62-512fc9d55946} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1009, line 1011) (in query: SELECT parseReadableSizeOrZero(NULL, NULL, NULL);) 2025.11.13 09:12:57.535579 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:57.743302 [ 18771 ] {9078e632-0ca0-4a5f-b459-6da4ed535175} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1013, line 1015) (in query: SELECT path(NULL, NULL, NULL);) 2025.11.13 09:12:57.749656 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:57.778654 [ 18771 ] {46e5d641-0de3-4572-8c9e-d005fe834029} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1014, line 1016) (in query: SELECT pathFull(NULL, NULL, NULL);) 2025.11.13 09:12:57.788112 [ 10181 ] {95447aed-b146-4377-bb50-0db9128eb778} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1483, line 1486) (in query: SELECT toUTCTimestamp(NULL, NULL, NULL);) 2025.11.13 09:12:57.788199 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:57.798649 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:57.942638 [ 18771 ] {4dc5570d-9d2a-40bd-9d8d-2761044bb97e} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1015, line 1017) (in query: SELECT percentRank(NULL, NULL, NULL);) 2025.11.13 09:12:57.950459 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:12:58.000457 [ 10181 ] {928f44ab-e06e-4e0b-8289-41e646ebb034} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1485, line 1488) (in query: SELECT toUUIDOrDefault(NULL, NULL, NULL);) 2025.11.13 09:12:58.009270 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.085903 [ 18771 ] {5f0a1b84-9521-444d-8991-8beed8fd62f8} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1016, line 1018) (in query: SELECT percent_rank(NULL, NULL, NULL);) 2025.11.13 09:12:58.099260 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:12:58.120996 [ 18771 ] {5197f74b-4016-420c-8510-7199643f6aa6} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1017, line 1019) (in query: SELECT pi(NULL, NULL, NULL);) 2025.11.13 09:12:58.136892 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.160231 [ 18771 ] {9e473f20-568a-4161-8b43-c9ca5d448a27} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1018, line 1020) (in query: SELECT plus(NULL, NULL, NULL);) 2025.11.13 09:12:58.166442 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.215716 [ 10181 ] {748ba5ad-6620-4cd2-9adf-da75692683ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1489, line 1492) (in query: SELECT toUnixTimestamp64Micro(NULL, NULL, NULL);) 2025.11.13 09:12:58.243610 [ 18771 ] {13899e77-1755-42aa-bbc3-80f3aa746a07} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1019, line 1021) (in query: SELECT pmod(NULL, NULL, NULL);) 2025.11.13 09:12:58.248768 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.317384 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.340412 [ 10181 ] {44c6bbc5-65d1-4b9a-9406-39c8fba53625} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1490, line 1493) (in query: SELECT toUnixTimestamp64Milli(NULL, NULL, NULL);) 2025.11.13 09:12:58.358498 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.374918 [ 18771 ] {22c0fe40-ad2a-4663-862a-a6eb55fe5137} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1022, line 1024) (in query: SELECT polygonAreaCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:58.379841 [ 10181 ] {78a50403-780d-4b4c-8067-b4b1b091a0d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1491, line 1494) (in query: SELECT toUnixTimestamp64Nano(NULL, NULL, NULL);) 2025.11.13 09:12:58.383319 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.387605 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.408015 [ 18771 ] {fb38f653-fbd5-491d-9dec-8c72cc3e0427} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1023, line 1025) (in query: SELECT polygonAreaSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:58.421270 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.467160 [ 10181 ] {e739e0f4-606c-465c-a26b-0eaab6d2fdd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1492, line 1495) (in query: SELECT toUnixTimestamp64Second(NULL, NULL, NULL);) 2025.11.13 09:12:58.472190 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.486873 [ 18771 ] {190fe339-72a4-4c3a-a0bc-a19a348c19c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1024, line 1026) (in query: SELECT polygonConvexHullCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:58.492854 [ 10181 ] {a082f9f1-5ffb-447b-b16d-81eff093cb8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1493, line 1496) (in query: SELECT toValidUTF8(NULL, NULL, NULL);) 2025.11.13 09:12:58.493331 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.500925 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.520314 [ 18771 ] {c107b3f4-78ff-437b-825b-24c01539d9b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1025, line 1027) (in query: SELECT polygonPerimeterCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:58.525347 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.557821 [ 18771 ] {ea1bb862-825f-4796-b24f-c480a219dcde} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1026, line 1028) (in query: SELECT polygonPerimeterSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:58.563308 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.592263 [ 18771 ] {7cd220a1-fd82-4f2b-bb9f-3bc38fb4afaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1027, line 1029) (in query: SELECT polygonsDistanceCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:58.602614 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.646133 [ 18771 ] {2af848aa-dcfd-4dd4-b5f2-d5b4b037025e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1028, line 1030) (in query: SELECT polygonsDistanceSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:58.674321 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.700881 [ 18771 ] {c47e9032-3e3c-46ef-a7f3-8a8956ea1fde} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1029, line 1031) (in query: SELECT polygonsEqualsCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:58.712792 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.741586 [ 18771 ] {5afd261f-0bf2-4f73-805c-e5d9be48589f} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1030, line 1032) (in query: SELECT polygonsIntersectionCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:58.746718 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.785310 [ 18771 ] {7c621943-b38d-44e7-b155-8f10cf306e2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1031, line 1033) (in query: SELECT polygonsIntersectionSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:58.791899 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.815106 [ 18771 ] {25fd55fa-0161-45ce-a9b2-4181f404d5b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1032, line 1034) (in query: SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:58.822669 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.858276 [ 18771 ] {6fa4dc9c-145e-40d7-88d5-5076517e3ca1} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1033, line 1035) (in query: SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:58.870551 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.894530 [ 18771 ] {17720902-e610-4b0f-9219-3f5009b62639} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1034, line 1036) (in query: SELECT polygonsUnionCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:58.900804 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.927878 [ 18771 ] {8fe61c81-dc81-4a06-b7ed-178a39a85eeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1035, line 1037) (in query: SELECT polygonsUnionSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:58.934516 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.963640 [ 18771 ] {5c11d1c4-eebf-4875-9abf-cf5dc8ddc181} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1036, line 1038) (in query: SELECT polygonsWithinCartesian(NULL, NULL, NULL);) 2025.11.13 09:12:58.972185 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:58.995490 [ 18771 ] {26b66125-0647-4de8-a094-93d435c0c912} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1037, line 1039) (in query: SELECT polygonsWithinSpherical(NULL, NULL, NULL);) 2025.11.13 09:12:59.032593 [ 10181 ] {4cd30b62-6ac2-41e5-a09f-4a90583d6b01} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1501, line 1504) (in query: SELECT to_utc_timestamp(NULL, NULL, NULL);) 2025.11.13 09:12:59.035816 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.040546 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.064848 [ 10181 ] {67e7254a-4aee-4e42-8a29-3820e0b27e59} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1502, line 1505) (in query: SELECT today(NULL, NULL, NULL);) 2025.11.13 09:12:59.069762 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.097197 [ 10181 ] {dbaf6ec5-002b-49c2-8a59-ff543dd51ba0} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1503, line 1506) (in query: SELECT tokens(NULL, NULL, NULL);) 2025.11.13 09:12:59.119081 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.348045 [ 10181 ] {96b25276-48db-43df-b0e7-8d11ca110e1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1506, line 1509) (in query: SELECT topLevelDomain(NULL, NULL, NULL);) 2025.11.13 09:12:59.353222 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.437635 [ 10181 ] {358ca495-e291-40f8-aefc-6853c8fc49a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1507, line 1510) (in query: SELECT topLevelDomainRFC(NULL, NULL, NULL);) 2025.11.13 09:12:59.444120 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.479657 [ 10181 ] {947019e2-2a48-4760-ac19-7a77c724cffb} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1508, line 1511) (in query: SELECT transactionID(NULL, NULL, NULL);) 2025.11.13 09:12:59.486650 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.536857 [ 10181 ] {c50463a8-13a1-43ec-b4b3-407852f66829} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1509, line 1512) (in query: SELECT transactionLatestSnapshot(NULL, NULL, NULL);) 2025.11.13 09:12:59.537672 [ 18771 ] {7803eabd-6b39-4988-88b9-a52481acbe61} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1044, line 1046) (in query: SELECT positiveModulo(NULL, NULL, NULL);) 2025.11.13 09:12:59.543045 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.546900 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.564725 [ 18771 ] {bc8f4634-ab08-4816-a729-9bb4c6526eea} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1045, line 1047) (in query: SELECT positive_modulo(NULL, NULL, NULL);) 2025.11.13 09:12:59.570917 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.588472 [ 10181 ] {b72e47f6-56d5-4847-834d-efbfc65d12bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1510, line 1513) (in query: SELECT transactionOldestSnapshot(NULL, NULL, NULL);) 2025.11.13 09:12:59.592154 [ 18771 ] {1da2ac17-8585-43a1-b209-e5285b3d04cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1046, line 1048) (in query: SELECT pow(NULL, NULL, NULL);) 2025.11.13 09:12:59.596801 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.599529 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.619825 [ 10181 ] {1ad05c4a-ced6-4ce2-8f17-415ce5ba8761} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1511, line 1514) (in query: SELECT transform(NULL, NULL, NULL);) 2025.11.13 09:12:59.624437 [ 18771 ] {5d9f4199-57b6-4ed3-8732-ecd371b095d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1047, line 1049) (in query: SELECT power(NULL, NULL, NULL);) 2025.11.13 09:12:59.629298 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:12:59.630468 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.697834 [ 18771 ] {34b5af63-635a-4442-87dd-cf834ffdf5af} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1049, line 1051) (in query: SELECT proportionsZTest(NULL, NULL, NULL);) 2025.11.13 09:12:59.729610 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.750281 [ 18771 ] {ed20ebd4-3068-4de5-a347-1a33a278ae98} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1050, line 1052) (in query: SELECT protocol(NULL, NULL, NULL);) 2025.11.13 09:12:59.755244 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.812110 [ 18771 ] {3d83e746-aa97-4678-987a-74431f28d718} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1051, line 1053) (in query: SELECT punycodeDecode(NULL, NULL, NULL);) 2025.11.13 09:12:59.818311 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:12:59.849635 [ 18771 ] {35f94cc4-b14f-4d86-b29b-61a1cd60d027} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1052, line 1054) (in query: SELECT punycodeEncode(NULL, NULL, NULL);) 2025.11.13 09:12:59.875294 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:00.222942 [ 10181 ] {5e07c54e-1391-45a7-b43a-329444f860cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1519, line 1523) (in query: SELECT tryBase58Decode(NULL, NULL, NULL);) 2025.11.13 09:13:00.229498 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:00.254669 [ 10181 ] {b063b019-c7c8-4c35-b262-ecd167b7cb87} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1520, line 1524) (in query: SELECT tryBase64Decode(NULL, NULL, NULL);) 2025.11.13 09:13:00.266973 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:00.290534 [ 10181 ] {b379bd5a-c662-4643-bd75-4566c6474186} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1521, line 1525) (in query: SELECT tryBase64URLDecode(NULL, NULL, NULL);) 2025.11.13 09:13:00.296906 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:00.394372 [ 10181 ] {b1fed6e1-c975-4c33-b7fe-260c9bdf8c1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1523, line 1527) (in query: SELECT tryIdnaEncode(NULL, NULL, NULL);) 2025.11.13 09:13:00.399936 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:00.424215 [ 10181 ] {8e9a41bb-7fe5-4ec3-9936-b8db1d6821bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1524, line 1528) (in query: SELECT tryPunycodeDecode(NULL, NULL, NULL);) 2025.11.13 09:13:00.438015 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:00.759375 [ 10181 ] {af1043cb-9813-413d-8b47-10d8079b9ad4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1530, line 1534) (in query: SELECT tupleDivide(NULL, NULL, NULL);) 2025.11.13 09:13:00.766559 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:00.799326 [ 10181 ] {03a76f49-74d9-4292-8079-168b181b6bfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1531, line 1535) (in query: SELECT tupleDivideByNumber(NULL, NULL, NULL);) 2025.11.13 09:13:00.808013 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:00.831693 [ 10181 ] {4abb0f97-c695-44bd-aff9-40302966babc} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1532, line 1536) (in query: SELECT tupleElement(NULL, NULL, NULL);) 2025.11.13 09:13:00.836865 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:00.858367 [ 10181 ] {9d44994a-1ec8-461e-ae82-dfb7fe9ca538} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1533, line 1537) (in query: SELECT tupleHammingDistance(NULL, NULL, NULL);) 2025.11.13 09:13:00.919630 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:00.947300 [ 10181 ] {10af96f0-41c9-4208-8fca-9bb5c408337c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1534, line 1538) (in query: SELECT tupleIntDiv(NULL, NULL, NULL);) 2025.11.13 09:13:00.956478 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:00.992322 [ 10181 ] {0f38b225-ce85-4979-b85c-a0ed0dd3628a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1535, line 1539) (in query: SELECT tupleIntDivByNumber(NULL, NULL, NULL);) 2025.11.13 09:13:01.003409 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.049438 [ 10181 ] {ff603e21-8a2f-470a-8327-6dd31affc9da} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1536, line 1540) (in query: SELECT tupleIntDivOrZero(NULL, NULL, NULL);) 2025.11.13 09:13:01.057745 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.075656 [ 10181 ] {52008e9b-31e1-4a0e-91ea-089d7e1ed7f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1537, line 1541) (in query: SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL);) 2025.11.13 09:13:01.083915 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.109625 [ 10181 ] {38518d87-a1d7-438f-80bf-06820b265540} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1538, line 1542) (in query: SELECT tupleMinus(NULL, NULL, NULL);) 2025.11.13 09:13:01.119142 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.141957 [ 10181 ] {6874921c-765b-4c75-9048-e345b0478409} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1539, line 1543) (in query: SELECT tupleModulo(NULL, NULL, NULL);) 2025.11.13 09:13:01.150375 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.204618 [ 10181 ] {04ccae58-c32f-4ebd-ad11-91c9d2b67e25} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1540, line 1544) (in query: SELECT tupleModuloByNumber(NULL, NULL, NULL);) 2025.11.13 09:13:01.209941 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.253235 [ 10181 ] {a96e2208-4544-4f2a-b972-685222b6dd44} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1541, line 1545) (in query: SELECT tupleMultiply(NULL, NULL, NULL);) 2025.11.13 09:13:01.264775 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.284498 [ 10181 ] {416d134b-b261-4d25-9dbb-fd272b5cd834} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1542, line 1546) (in query: SELECT tupleMultiplyByNumber(NULL, NULL, NULL);) 2025.11.13 09:13:01.292460 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.310092 [ 10181 ] {17f75068-1efb-4ca1-b466-8907b514336a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1543, line 1547) (in query: SELECT tupleNames(NULL, NULL, NULL);) 2025.11.13 09:13:01.317931 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.361947 [ 10181 ] {3349f5a3-56a2-4ac6-8134-b48a65fd9254} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1544, line 1548) (in query: SELECT tupleNegate(NULL, NULL, NULL);) 2025.11.13 09:13:01.369669 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.387809 [ 10181 ] {6991c88d-afd3-4991-aa4b-a9f47662d14a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1545, line 1549) (in query: SELECT tuplePlus(NULL, NULL, NULL);) 2025.11.13 09:13:01.399383 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.419933 [ 10181 ] {8363696b-2f04-43a4-9ccc-bbb6ff0a17f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1546, line 1550) (in query: SELECT tupleToNameValuePairs(NULL, NULL, NULL);) 2025.11.13 09:13:01.434335 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.456935 [ 10181 ] {d08f3e68-aa01-4674-b814-81cd492ab44a} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1547, line 1551) (in query: SELECT ucase(NULL, NULL, NULL);) 2025.11.13 09:13:01.462906 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.487640 [ 10181 ] {f1700725-b84d-4aa0-b076-ccb30f3bd2bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1548, line 1552) (in query: SELECT unbin(NULL, NULL, NULL);) 2025.11.13 09:13:01.566866 [ 16920 ] {6ca68c2f-d84c-4f31-9e77-eb1620e14c03} executeQuery: Code: 57. DB::Exception: Table test_15.aine already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38322) (comment: 01073_attach_if_not_exists.sql) (query 2, line 3) (in query: ATTACH TABLE aine;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:01.569247 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:01.570279 [ 16920 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.aine already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:01.590949 [ 10181 ] {3b79bf18-6f31-40f8-876f-bde94551438f} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1549, line 1553) (in query: SELECT unhex(NULL, NULL, NULL);) 2025.11.13 09:13:01.599412 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:02.128090 [ 18771 ] {9a791903-07c6-4004-abb5-c561794ca39b} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1071, line 1073) (in query: SELECT quantiles(NULL, NULL, NULL);) 2025.11.13 09:13:02.128090 [ 10181 ] {45fe161d-4278-45d1-b86b-c9090678f46a} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1556, line 1560) (in query: SELECT uniqThetaIntersect(NULL, NULL, NULL);) 2025.11.13 09:13:02.136005 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:02.137614 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.153860 [ 10181 ] {dd1c426f-39c2-44be-ba5f-c34de0212856} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1557, line 1561) (in query: SELECT uniqThetaNot(NULL, NULL, NULL);) 2025.11.13 09:13:02.157421 [ 18771 ] {2c1c7d4f-912e-4f9a-9af6-6df3b105d1e6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1072, line 1074) (in query: SELECT quantilesBFloat16(NULL, NULL, NULL);) 2025.11.13 09:13:02.161723 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:02.181823 [ 10181 ] {fba43341-4b91-4d30-973f-89de60e4b54e} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1558, line 1562) (in query: SELECT uniqThetaUnion(NULL, NULL, NULL);) 2025.11.13 09:13:02.186912 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:02.222159 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.275234 [ 10181 ] {f82f66d1-1aa3-44b4-a4ec-b5fb92be6d82} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1560, line 1564) (in query: SELECT upper(NULL, NULL, NULL);) 2025.11.13 09:13:02.282202 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:02.377351 [ 10181 ] {8c4b10e4-cfdb-4e44-b2b1-465005be82b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1561, line 1565) (in query: SELECT upperUTF8(NULL, NULL, NULL);) 2025.11.13 09:13:02.385067 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:02.390932 [ 16693 ] {323802db-2730-41a4-88c8-682c1d58e700} executeQuery: Code: 36. DB::Exception: Identifier 'test_foo_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38306) (comment: 03234_enable_secure_identifiers.sql) (query 2, line 2) (in query: CREATE TABLE `test_foo_#` ( `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000003dfa9839 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003dfa8be5 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e0a7cc9 9. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df24169 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:13:02.395355 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'test_foo_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000003dfa9839 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003dfa8be5 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e0a7cc9 9. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df24169 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:13:02.402056 [ 10181 ] {864aa84f-6de1-4fef-9d1b-59540163436b} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1562, line 1566) (in query: SELECT uptime(NULL, NULL, NULL);) 2025.11.13 09:13:02.404196 [ 18771 ] {fbdd9d29-ff8b-4358-aa31-88a3db6345f1} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1074, line 1076) (in query: SELECT quantilesDD(NULL, NULL, NULL);) 2025.11.13 09:13:02.410198 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:02.416465 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.428508 [ 10181 ] {c5b947a4-4890-422a-ba31-cea54c0202a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1563, line 1567) (in query: SELECT user(NULL, NULL, NULL);) 2025.11.13 09:13:02.436596 [ 18771 ] {2dc169d0-228e-456e-ba0e-7ae6de079403} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1075, line 1077) (in query: SELECT quantilesDeterministic(NULL, NULL, NULL);) 2025.11.13 09:13:02.437760 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:02.442010 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.467913 [ 18771 ] {be28d4e8-a7fa-4f0c-9664-ef39bdf0eb6b} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1076, line 1078) (in query: SELECT quantilesExact(NULL, NULL, NULL);) 2025.11.13 09:13:02.473686 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.509895 [ 18771 ] {5da466ba-82c8-401f-8277-a01e9076eb25} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1077, line 1079) (in query: SELECT quantilesExactExclusive(NULL, NULL, NULL);) 2025.11.13 09:13:02.515445 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.542045 [ 18771 ] {78175d09-ab1e-4a97-bf5a-70a9e1826cca} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1078, line 1080) (in query: SELECT quantilesExactHigh(NULL, NULL, NULL);) 2025.11.13 09:13:02.549125 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.570140 [ 18771 ] {dcdbe394-9954-4293-96dd-08674ae36209} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1079, line 1081) (in query: SELECT quantilesExactInclusive(NULL, NULL, NULL);) 2025.11.13 09:13:02.576117 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.597554 [ 18771 ] {f72edc3a-30e1-458e-9a1c-23792eb794b5} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1080, line 1082) (in query: SELECT quantilesExactLow(NULL, NULL, NULL);) 2025.11.13 09:13:02.610694 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.635537 [ 18771 ] {25d0d7be-b01f-4481-a576-cf91abc9a523} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1081, line 1083) (in query: SELECT quantilesExactWeighted(NULL, NULL, NULL);) 2025.11.13 09:13:02.642355 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.643944 [ 3730 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_41_8} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:02.644976 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_41_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:02.666459 [ 18771 ] {642aefcd-9437-4bf4-8a10-f95c4c3a7c73} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1082, line 1084) (in query: SELECT quantilesExactWeightedInterpolated(NULL, NULL, NULL);) 2025.11.13 09:13:02.674024 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.693616 [ 18771 ] {59010a84-923b-46ac-b69e-deb1649e0ce8} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1083, line 1085) (in query: SELECT quantilesGK(NULL, NULL, NULL);) 2025.11.13 09:13:02.700916 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.721562 [ 18771 ] {ffd16605-2755-421a-a640-ae1fc1b10e1f} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1084, line 1086) (in query: SELECT quantilesInterpolatedWeighted(NULL, NULL, NULL);) 2025.11.13 09:13:02.727266 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.746950 [ 18771 ] {6910832c-0c17-4088-976b-5ea1aea62348} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1085, line 1087) (in query: SELECT quantilesTDigest(NULL, NULL, NULL);) 2025.11.13 09:13:02.834729 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.861074 [ 18771 ] {69e0a1fd-717f-4b5a-bf07-e3504530b5ad} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1086, line 1088) (in query: SELECT quantilesTDigestWeighted(NULL, NULL, NULL);) 2025.11.13 09:13:02.872493 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.902131 [ 18771 ] {3f5d6496-cbf1-4539-81c3-7cb04eeadbd9} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1087, line 1089) (in query: SELECT quantilesTiming(NULL, NULL, NULL);) 2025.11.13 09:13:02.907920 [ 10181 ] {5b0d56bd-b13b-4140-9307-d0f98971976f} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1569, line 1573) (in query: SELECT variantElement(NULL, NULL, NULL);) 2025.11.13 09:13:02.917179 [ 10181 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.920377 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.945460 [ 18771 ] {83b27d2b-3e18-45c7-8eaf-cda13998d903} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1088, line 1090) (in query: SELECT quantilesTimingWeighted(NULL, NULL, NULL);) 2025.11.13 09:13:02.945683 [ 10181 ] {7ef1c091-a98f-410a-8d69-1296d59c4f71} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1570, line 1574) (in query: SELECT variantType(NULL, NULL, NULL);) 2025.11.13 09:13:02.956187 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:02.957150 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:02.998766 [ 10181 ] {65dd5efc-3baf-42f5-88e2-325c3ec7daaf} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1571, line 1575) (in query: SELECT vectorDifference(NULL, NULL, NULL);) 2025.11.13 09:13:03.010043 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.010379 [ 18771 ] {880b53d0-b584-4a3b-a552-95f8199a8bc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1089, line 1091) (in query: SELECT queryID(NULL, NULL, NULL);) 2025.11.13 09:13:03.024291 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.047735 [ 18771 ] {ec995103-7dff-46e5-bbdc-1a6d2fd94762} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1090, line 1092) (in query: SELECT queryString(NULL, NULL, NULL);) 2025.11.13 09:13:03.058226 [ 10181 ] {9d4232a1-5a99-4fcf-b529-c2255755e534} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1572, line 1576) (in query: SELECT vectorSum(NULL, NULL, NULL);) 2025.11.13 09:13:03.062868 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.066655 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.083216 [ 18771 ] {636eb0c1-a800-4bf8-9abe-f63c07a31d09} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1091, line 1093) (in query: SELECT queryStringAndFragment(NULL, NULL, NULL);) 2025.11.13 09:13:03.089274 [ 10181 ] {bd44f737-b7c8-4989-a7b5-6889947a7e6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1573, line 1577) (in query: SELECT version(NULL, NULL, NULL);) 2025.11.13 09:13:03.092064 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.095571 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.117132 [ 10181 ] {c4813da7-bce6-4f9b-ad47-f068af200ff1} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1574, line 1578) (in query: SELECT visibleWidth(NULL, NULL, NULL);) 2025.11.13 09:13:03.117507 [ 18771 ] {0b0660a3-fab3-446b-bfa7-db0721be9929} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1092, line 1094) (in query: SELECT query_id(NULL, NULL, NULL);) 2025.11.13 09:13:03.125460 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.131688 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.147441 [ 10181 ] {4f24cdc0-5a90-4ee7-9a6e-69bfd1c05f98} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1575, line 1579) (in query: SELECT visitParamExtractBool(NULL, NULL, NULL);) 2025.11.13 09:13:03.153040 [ 18771 ] {278e6f7e-bd40-4306-bed3-9c8c74774811} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1093, line 1095) (in query: SELECT radians(NULL, NULL, NULL);) 2025.11.13 09:13:03.157408 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.165600 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.185343 [ 10181 ] {eb48cc3a-cfe9-4be8-a69a-51918d147efb} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1576, line 1580) (in query: SELECT visitParamExtractFloat(NULL, NULL, NULL);) 2025.11.13 09:13:03.195630 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.217509 [ 10181 ] {fdcd2d3c-3f4d-49d6-bcbb-9884d723ec69} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1577, line 1581) (in query: SELECT visitParamExtractInt(NULL, NULL, NULL);) 2025.11.13 09:13:03.224308 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.242781 [ 10181 ] {4fb17121-3af7-4770-b367-5baf6319d00d} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1578, line 1582) (in query: SELECT visitParamExtractRaw(NULL, NULL, NULL);) 2025.11.13 09:13:03.247367 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.348254 [ 18771 ] {b076a261-e5ae-4f46-860c-6c48930848aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1094, line 1096) (in query: SELECT rand(NULL, NULL, NULL);) 2025.11.13 09:13:03.349867 [ 10181 ] {ad37bd01-eba2-4f32-83c9-bc7f0747312e} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1579, line 1583) (in query: SELECT visitParamExtractString(NULL, NULL, NULL);) 2025.11.13 09:13:03.354228 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.360054 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.376025 [ 18771 ] {8aadcc0b-1b51-44b9-b797-b382da384859} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1095, line 1097) (in query: SELECT rand32(NULL, NULL, NULL);) 2025.11.13 09:13:03.383328 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.407785 [ 18771 ] {22037489-ff4a-4ebf-8d51-ad6422a8de35} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1096, line 1098) (in query: SELECT rand64(NULL, NULL, NULL);) 2025.11.13 09:13:03.413784 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.453140 [ 10181 ] {571b90f9-e39b-41e9-824a-22319f769cbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1580, line 1584) (in query: SELECT visitParamExtractUInt(NULL, NULL, NULL);) 2025.11.13 09:13:03.453462 [ 16693 ] {9c6a8c60-efe7-4026-ac37-232c972dd22b} executeQuery: Code: 36. DB::Exception: Identifier 'insecure_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38306) (comment: 03234_enable_secure_identifiers.sql) (query 5, line 16) (in query: CREATE TABLE test_foo ( `insecure_#` Int8, `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:13:03.457327 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'insecure_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:13:03.472736 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.489875 [ 10181 ] {723e3af6-4204-4019-ab50-4716b82e1795} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1581, line 1585) (in query: SELECT visitParamHas(NULL, NULL, NULL);) 2025.11.13 09:13:03.497599 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.501795 [ 16693 ] {3efc859e-3644-4e02-9adc-58b2b6dc456b} executeQuery: Code: 36. DB::Exception: Identifier 'insecure_'' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38306) (comment: 03234_enable_secure_identifiers.sql) (query 7, line 29) (in query: CREATE TABLE test_foo ( `insecure_'` Int8, `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:13:03.564196 [ 18771 ] {67d22363-0ee8-41d4-b030-5e818a0d002e} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1099, line 1101) (in query: SELECT randCanonical(NULL, NULL, NULL);) 2025.11.13 09:13:03.570801 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.594573 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'insecure_'' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:13:03.639146 [ 16693 ] {b8a627f5-43c7-4a95-bc9f-6f7a6c36d6e0} executeQuery: Code: 36. DB::Exception: Identifier 'insecure_"' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38306) (comment: 03234_enable_secure_identifiers.sql) (query 9, line 42) (in query: CREATE TABLE test_foo ( `insecure_"` Int8, `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:13:03.643199 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'insecure_"' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:13:03.697201 [ 10181 ] {72d208e0-6191-425d-9df9-033add65191c} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1584, line 1588) (in query: SELECT widthBucket(NULL, NULL, NULL);) 2025.11.13 09:13:03.715614 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.740051 [ 10181 ] {c5f04e13-d86e-4498-9ea2-b215cb42162a} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1585, line 1589) (in query: SELECT width_bucket(NULL, NULL, NULL);) 2025.11.13 09:13:03.744432 [ 18771 ] {a6e33766-d0d7-48b8-9155-4b4c19af7495} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1101, line 1103) (in query: SELECT randConstant(NULL, NULL, NULL);) 2025.11.13 09:13:03.750792 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:03.752924 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:04.005447 [ 10181 ] {c5b4ea85-2755-4e09-a0b5-8664d8bc3de0} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1588, line 1592) (in query: SELECT wkt(NULL, NULL, NULL);) 2025.11.13 09:13:04.021490 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:04.468060 [ 16192 ] {a7249363-9722-4ff1-8730-65b9d6facef4} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36990) (comment: 02904_distributed_settings_background_insert_compatibility.gen.sql) (in query: DROP DATABASE IF EXISTS test_f63tw0eg SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:13:04.471368 [ 16192 ] {a7249363-9722-4ff1-8730-65b9d6facef4} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:04.538757 [ 18771 ] {1764e4c0-b160-41cc-acbc-c231a5187ab5} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1110, line 1112) (in query: SELECT randomFixedString(NULL, NULL, NULL);) 2025.11.13 09:13:04.549939 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:04.740596 [ 18771 ] {ecf6f5bf-1cbc-4a5d-aac5-df60adf5ff3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1113, line 1115) (in query: SELECT randomStringUTF8(NULL, NULL, NULL);) 2025.11.13 09:13:04.746806 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:04.845658 [ 18771 ] {45490342-7abb-4c0f-8cb8-38d1b4e55b86} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1115, line 1117) (in query: SELECT rank(NULL, NULL, NULL);) 2025.11.13 09:13:04.855613 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:13:04.944181 [ 18771 ] {e417416b-1426-4ed4-9f7d-e31dec4b154f} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1117, line 1119) (in query: SELECT readWKTLineString(NULL, NULL, NULL);) 2025.11.13 09:13:04.957922 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:04.978885 [ 18771 ] {54c35c35-d613-4e0f-8520-339e43d7aa15} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1118, line 1120) (in query: SELECT readWKTMultiLineString(NULL, NULL, NULL);) 2025.11.13 09:13:04.985271 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.006076 [ 18771 ] {d1eaae83-60b9-4ab8-bc21-2e7abe96dc0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1119, line 1121) (in query: SELECT readWKTMultiPolygon(NULL, NULL, NULL);) 2025.11.13 09:13:05.011290 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.028895 [ 18376 ] {03276_null_format_matching_case_insensitive_760122466} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.54 GiB (attempt to allocate chunk of 1.50 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40094) (comment: 03276_null_format_matching_case_insensitive.sh) (query 1, line 1) (in query: select * from numbers_mt(1e8) format null settings max_rows_to_read=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 10. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b29a0d 11. ./src/Columns/IColumn.h:210: DB::Chunk::append(DB::Chunk const&, unsigned long, unsigned long) @ 0x000000003b167451 12. ./build_docker/./src/Interpreters/Cache/QueryResultCache.cpp:467: DB::QueryResultCacheWriter::finalizeWrite() @ 0x0000000033b6ba5f 13. ./build_docker/./src/Processors/Transforms/StreamInQueryResultCacheTransform.cpp:24: DB::StreamInQueryResultCacheTransform::finalizeWriteInQueryResultCache() @ 0x000000003bcc821d 14. ./build_docker/./src/QueryPipeline/QueryPipeline.cpp:658: DB::QueryPipeline::finalizeWriteInQueryResultCache() @ 0x000000002f21b7dc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1573: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&)::$_1, void (DB::QueryPipeline&)>>(std::__function::__policy_storage const*, DB::QueryPipeline&) @ 0x0000000033850d01 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1c810e 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003aea4c02 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:05.033162 [ 18771 ] {ec5b0fab-2ccd-4205-aa98-fa201965e7b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1120, line 1122) (in query: SELECT readWKTPoint(NULL, NULL, NULL);) 2025.11.13 09:13:05.040144 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.127920 [ 18771 ] {0700daf5-25df-42fc-9179-16504428ffa1} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1121, line 1123) (in query: SELECT readWKTPolygon(NULL, NULL, NULL);) 2025.11.13 09:13:05.144896 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.167579 [ 18771 ] {e3c25668-7b70-4104-bcaa-e3c197e9bea9} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1122, line 1124) (in query: SELECT readWKTRing(NULL, NULL, NULL);) 2025.11.13 09:13:05.178997 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.241197 [ 18771 ] {bcd9efcd-f210-417f-bdbd-e270510496ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1124, line 1126) (in query: SELECT regexpQuoteMeta(NULL, NULL, NULL);) 2025.11.13 09:13:05.248501 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.637631 [ 10181 ] {51a13f02-7c93-4427-83da-dd8b6a965034} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1606, line 1610) (in query: SELECT yandexConsistentHash(NULL, NULL, NULL);) 2025.11.13 09:13:05.645010 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.712195 [ 10181 ] {1d33849c-970f-4ebf-8a53-8f856f9d37d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1608, line 1612) (in query: SELECT yesterday(NULL, NULL, NULL);) 2025.11.13 09:13:05.719853 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.738610 [ 16693 ] {6bab3b21-ae6e-4f03-852c-8dbd58851b95} executeQuery: Code: 36. DB::Exception: Identifier 'test_foo$' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38306) (comment: 03234_enable_secure_identifiers.sql) (query 20, line 106) (in query: -- SHOW CREATE .. query contains an insecure identifier (`test_foo$`) with `enforce_strict_identifier_format` SHOW CREATE TABLE `test_foo$` SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000003dfa9839 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003dfa8be5 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e0a7cc9 9. ./src/Parsers/IAST.h:266: DB::ASTQueryWithTableAndOutputImpl::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e2a43f4 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:13:05.741925 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'test_foo$' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000003dfa9839 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003dfa8be5 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e0a7cc9 9. ./src/Parsers/IAST.h:266: DB::ASTQueryWithTableAndOutputImpl::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e2a43f4 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:13:05.823217 [ 10181 ] {842d9faa-0917-42d5-a054-63c8e74faec3} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59658) (comment: 00534_functions_bad_arguments11.sh) (query 1609, line 1613) (in query: SELECT zookeeperSessionUptime(NULL, NULL, NULL);) 2025.11.13 09:13:05.846220 [ 10181 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.881845 [ 18376 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.54 GiB (attempt to allocate chunk of 1.50 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 10. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b29a0d 11. ./src/Columns/IColumn.h:210: DB::Chunk::append(DB::Chunk const&, unsigned long, unsigned long) @ 0x000000003b167451 12. ./build_docker/./src/Interpreters/Cache/QueryResultCache.cpp:467: DB::QueryResultCacheWriter::finalizeWrite() @ 0x0000000033b6ba5f 13. ./build_docker/./src/Processors/Transforms/StreamInQueryResultCacheTransform.cpp:24: DB::StreamInQueryResultCacheTransform::finalizeWriteInQueryResultCache() @ 0x000000003bcc821d 14. ./build_docker/./src/QueryPipeline/QueryPipeline.cpp:658: DB::QueryPipeline::finalizeWriteInQueryResultCache() @ 0x000000002f21b7dc 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1573: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&)::$_1, void (DB::QueryPipeline&)>>(std::__function::__policy_storage const*, DB::QueryPipeline&) @ 0x0000000033850d01 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1c810e 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003aea4c02 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:05.916972 [ 18771 ] {1c255bec-fd9f-4924-b4b3-a32c1f0b9077} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1135, line 1137) (in query: SELECT reinterpret(NULL, NULL, NULL);) 2025.11.13 09:13:05.929445 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.951689 [ 18771 ] {24830975-20be-4616-bc9f-bbe512c1a6a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1136, line 1138) (in query: SELECT reinterpretAsDate(NULL, NULL, NULL);) 2025.11.13 09:13:05.957804 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:05.981358 [ 18771 ] {c3389283-037f-4a8d-ac2b-1a8b4c9842e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1137, line 1139) (in query: SELECT reinterpretAsDateTime(NULL, NULL, NULL);) 2025.11.13 09:13:05.992933 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.028828 [ 18771 ] {51048aaf-3d19-49ba-a2b9-4f1c3801e121} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1138, line 1140) (in query: SELECT reinterpretAsFixedString(NULL, NULL, NULL);) 2025.11.13 09:13:06.041964 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.070453 [ 18771 ] {fca88ca6-c4b3-4743-aad6-0963e28cdcc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1139, line 1141) (in query: SELECT reinterpretAsFloat32(NULL, NULL, NULL);) 2025.11.13 09:13:06.078864 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.102176 [ 18771 ] {8ba8afb7-36f4-4221-ab36-c84c38e206e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1140, line 1142) (in query: SELECT reinterpretAsFloat64(NULL, NULL, NULL);) 2025.11.13 09:13:06.117957 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.139275 [ 18771 ] {546b0194-e97d-48f9-8bbb-0fb9e97ec47b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1141, line 1143) (in query: SELECT reinterpretAsInt128(NULL, NULL, NULL);) 2025.11.13 09:13:06.144414 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.163909 [ 18771 ] {3910f8ce-03a4-4b8a-8e78-5505fc00f587} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1142, line 1144) (in query: SELECT reinterpretAsInt16(NULL, NULL, NULL);) 2025.11.13 09:13:06.203957 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.226814 [ 18771 ] {f05148a2-76c7-4bab-9218-557cd1387ff7} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1143, line 1145) (in query: SELECT reinterpretAsInt256(NULL, NULL, NULL);) 2025.11.13 09:13:06.231911 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.256313 [ 18771 ] {9dd0c2fc-b482-40a0-93e0-610077876d2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1144, line 1146) (in query: SELECT reinterpretAsInt32(NULL, NULL, NULL);) 2025.11.13 09:13:06.260984 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.284928 [ 18771 ] {87b8836e-84c8-4d31-861a-f0aca44de896} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1145, line 1147) (in query: SELECT reinterpretAsInt64(NULL, NULL, NULL);) 2025.11.13 09:13:06.292071 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.314552 [ 18771 ] {48b4daf6-3196-4ba4-8615-6f78f1a68d2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1146, line 1148) (in query: SELECT reinterpretAsInt8(NULL, NULL, NULL);) 2025.11.13 09:13:06.325191 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.358244 [ 18771 ] {809a16b2-a78a-4fd2-8882-1ffc416caf8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1147, line 1149) (in query: SELECT reinterpretAsString(NULL, NULL, NULL);) 2025.11.13 09:13:06.363295 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.454183 [ 18771 ] {a89a460d-32e2-42ee-9119-d6e8b0d05dcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1148, line 1150) (in query: SELECT reinterpretAsUInt128(NULL, NULL, NULL);) 2025.11.13 09:13:06.514545 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.536149 [ 18771 ] {30a01306-db02-403b-b411-9ebaeb337a45} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1149, line 1151) (in query: SELECT reinterpretAsUInt16(NULL, NULL, NULL);) 2025.11.13 09:13:06.545912 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.590381 [ 18771 ] {0b2265c8-bb85-4827-88c2-a9fa4307d669} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1150, line 1152) (in query: SELECT reinterpretAsUInt256(NULL, NULL, NULL);) 2025.11.13 09:13:06.595598 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.620885 [ 18771 ] {23be3576-31db-47be-a5a7-21fbd7ffc491} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1151, line 1153) (in query: SELECT reinterpretAsUInt32(NULL, NULL, NULL);) 2025.11.13 09:13:06.630021 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.646655 [ 18771 ] {9edb3992-09ed-43db-bd9a-4877b9e38dba} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1152, line 1154) (in query: SELECT reinterpretAsUInt64(NULL, NULL, NULL);) 2025.11.13 09:13:06.651592 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.672972 [ 18771 ] {58def2c7-24db-4201-9503-f0b51075dbd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1153, line 1155) (in query: SELECT reinterpretAsUInt8(NULL, NULL, NULL);) 2025.11.13 09:13:06.679615 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.699767 [ 18771 ] {0fef55ef-6c44-4c95-b24a-ef5d7f1a9439} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1154, line 1156) (in query: SELECT reinterpretAsUUID(NULL, NULL, NULL);) 2025.11.13 09:13:06.706344 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:06.707080 [ 16323 ] {6b17567e-796d-460d-b0d6-18df9a2e2acf} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38566) (comment: 02352_lightweight_delete_and_object_column.sql) (query 2, line 3) (in query: SET allow_experimental_object_type=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:13:06.714122 [ 16323 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:13:06.727230 [ 18771 ] {e67d9b93-6745-4c5f-87ec-69fa1f453630} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1155, line 1157) (in query: SELECT repeat(NULL, NULL, NULL);) 2025.11.13 09:13:06.737857 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:07.172553 [ 18771 ] {305a4ba5-92f0-4ddc-bceb-844a9350bf74} executeQuery: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1161, line 1163) (in query: SELECT replicate(NULL, NULL, NULL);) 2025.11.13 09:13:07.177600 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Argument 2 for function replicate must be array.: In scope SELECT replicate(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:07.259710 [ 18771 ] {41611eef-fe15-4ac8-905b-7e5192917549} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1163, line 1165) (in query: SELECT reverse(NULL, NULL, NULL);) 2025.11.13 09:13:07.266216 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:07.291476 [ 18771 ] {f3a1aaec-5033-4b6b-93fc-32e2f50b2d28} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1164, line 1166) (in query: SELECT reverseUTF8(NULL, NULL, NULL);) 2025.11.13 09:13:07.295437 [ 16352 ] {90419765-d0ab-4ce8-bda9-723fc7209be5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 15_UInt8) :: 0) -> throwIf(equals(__table1.number, 15_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56180) (comment: 03174_json_compact_with_progress.sh) (in query: SELECT throwIf(number = 15), 1::Int64 as a, '"' from numbers(100) format JSONCompactEachRowWithProgress settings output_format_json_quote_64bit_integers=1, max_block_size=10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:13:07.301785 [ 16352 ] {90419765-d0ab-4ce8-bda9-723fc7209be5} DynamicQueryHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 15_UInt8) :: 0) -> throwIf(equals(__table1.number, 15_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 19. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 20. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 21. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:07.313991 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:07.336703 [ 18771 ] {e9af3138-b13b-4006-ac31-dbd482c0401c} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1165, line 1167) (in query: SELECT revision(NULL, NULL, NULL);) 2025.11.13 09:13:07.341620 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:07.362803 [ 18771 ] {1ff6d520-b621-4cc7-a981-7d3a8114c4c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1166, line 1168) (in query: SELECT right(NULL, NULL, NULL);) 2025.11.13 09:13:07.371854 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:07.480047 [ 18771 ] {3106b79c-ca26-416c-886a-a64c9e779668} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1169, line 1171) (in query: SELECT rightUTF8(NULL, NULL, NULL);) 2025.11.13 09:13:07.486075 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:07.558251 [ 18771 ] {a36fbdda-abe9-4866-b9f7-b43cf584810e} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1171, line 1173) (in query: SELECT roundAge(NULL, NULL, NULL);) 2025.11.13 09:13:07.567424 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:07.803362 [ 18771 ] {fd9dff79-f223-4b16-8e25-ed63f1fcc3f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1173, line 1175) (in query: SELECT roundDown(NULL, NULL, NULL);) 2025.11.13 09:13:07.923047 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:08.037478 [ 18771 ] {075141bd-1464-4b05-81f1-3e73f6d61126} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1174, line 1176) (in query: SELECT roundDuration(NULL, NULL, NULL);) 2025.11.13 09:13:08.043566 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:08.070486 [ 18771 ] {ba9492a9-ef3b-4734-ad2b-3bf74296360d} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1175, line 1177) (in query: SELECT roundToExp2(NULL, NULL, NULL);) 2025.11.13 09:13:08.080735 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:08.114787 [ 16192 ] {acd2f311-bdac-46ea-88b9-cd1a849f225e} DynamicQueryHandler: Code: 271. DB::Exception: Invalid zero byte count(s): 5 and 1. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::CompressionCodecFPC::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000003de4e4af 4. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000003de7e2f3 5. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:329: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x000000003dd31179 6. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000003dd2b846 7. DB::ReadBuffer::next() @ 0x0000000008ef7cef 8. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000001f961366 9. DB::ReadBuffer::next() @ 0x0000000008ef7cef 10. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x00000000316a2ab7 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003383f5fa 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:08.170239 [ 18771 ] {2acc7c32-c2bf-4e75-8c1b-93195d1a8ea9} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1176, line 1178) (in query: SELECT rowNumberInAllBlocks(NULL, NULL, NULL);) 2025.11.13 09:13:08.181010 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:08.293553 [ 18771 ] {15d740c5-a664-458f-b1f9-d727c9aeab63} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1177, line 1179) (in query: SELECT rowNumberInBlock(NULL, NULL, NULL);) 2025.11.13 09:13:08.304168 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:08.373249 [ 18771 ] {f1d1b6f4-5b15-4698-91c0-33091f1ab008} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1178, line 1180) (in query: SELECT row_number(NULL, NULL, NULL);) 2025.11.13 09:13:08.387606 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:13:08.456448 [ 18771 ] {177ace21-364f-499d-804f-e23f8ee6ba93} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1180, line 1183) (in query: SELECT runningAccumulate(NULL, NULL, NULL);) 2025.11.13 09:13:08.462917 [ 18771 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:13:08.531778 [ 18771 ] {cc62d5c8-43df-42d2-a9a1-98270ea617ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1181, line 1184) (in query: SELECT runningConcurrency(NULL, NULL, NULL);) 2025.11.13 09:13:08.537920 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:08.557078 [ 18771 ] {56d2c0aa-b1d6-40a0-94d6-1bc17b1430d3} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1182, line 1185) (in query: SELECT runningDifference(NULL, NULL, NULL);) 2025.11.13 09:13:08.647744 [ 18771 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:13:08.674102 [ 16323 ] {a0126386-4c72-4eaf-a267-851c0002dbda} DynamicQueryHandler: Code: 271. DB::Exception: Invalid zero byte count(s): 1 and 6. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::CompressionCodecFPC::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000003de4e4af 4. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000003de7e2f3 5. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:329: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x000000003dd31179 6. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000003dd2b846 7. DB::ReadBuffer::next() @ 0x0000000008ef7cef 8. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000001f961366 9. DB::ReadBuffer::next() @ 0x0000000008ef7cef 10. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x00000000316a2ab7 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003383f5fa 13. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:08.777888 [ 18771 ] {ab687a9c-6722-420f-a094-f8df77fa574a} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1183, line 1186) (in query: SELECT runningDifferenceStartingWithFirstValue(NULL, NULL, NULL);) 2025.11.13 09:13:08.788240 [ 18771 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:13:08.887011 [ 18771 ] {0639273b-105d-4400-840f-0c502bc6f1fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1185, line 1188) (in query: SELECT s2CapUnion(NULL, NULL, NULL);) 2025.11.13 09:13:08.897442 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:08.915664 [ 18771 ] {7db30552-0640-461f-b0ac-3894258dda8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1186, line 1189) (in query: SELECT s2CellsIntersect(NULL, NULL, NULL);) 2025.11.13 09:13:08.959653 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:08.994629 [ 18771 ] {bc97549e-03d5-4f45-bdd3-dbc86eb3d949} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1187, line 1190) (in query: SELECT s2GetNeighbors(NULL, NULL, NULL);) 2025.11.13 09:13:09.002525 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.210310 [ 18771 ] {5577ca33-79d3-4133-b320-33c666132b17} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1190, line 1193) (in query: SELECT s2RectIntersection(NULL, NULL, NULL);) 2025.11.13 09:13:09.215016 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.236854 [ 18771 ] {ac30303c-a89f-44af-8d61-75260bb3c83d} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1191, line 1194) (in query: SELECT s2RectUnion(NULL, NULL, NULL);) 2025.11.13 09:13:09.241750 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.264423 [ 18771 ] {bdd84407-09a5-4558-be2e-32e7ad36734a} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1192, line 1195) (in query: SELECT s2ToGeo(NULL, NULL, NULL);) 2025.11.13 09:13:09.273991 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.322873 [ 18771 ] {6004da9b-f757-472c-aab3-ac6fb8e2b43a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1193, line 1196) (in query: SELECT scalarProduct(NULL, NULL, NULL);) 2025.11.13 09:13:09.330162 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.367231 [ 16195 ] {23e97feb-7cb6-48c5-8a6d-7fc60b99c6f7} executeQuery: Code: 57. DB::Exception: Table test_5.test_02312 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02312_parquet_orc_arrow_names_tuples.sql) (in query: /* ddl_entry=query-0000000092 */ CREATE TABLE test_5.test_02312 UUID '2b7083c1-e8a5-4603-bae4-1fcae89af476' (`a.b` Array(Nested(c UInt32))) ENGINE = File(Arrow)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:09.379324 [ 16195 ] {23e97feb-7cb6-48c5-8a6d-7fc60b99c6f7} executeQuery: Code: 57. DB::Exception: Table test_5.test_02312 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38574) (comment: 02312_parquet_orc_arrow_names_tuples.sql) (query 18, line 21) (in query: create table test_02312 (a Nested(b Nested(c UInt32))) engine=File(Arrow);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:09.396046 [ 16195 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.test_02312 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:09.619358 [ 10170 ] {49ad642a-2e0c-414d-a605-4333551c90b3} executeQuery: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: String. In query SELECT t0.c2, t0.c1, t0.c0 FROM t0 PREWHERE t0.c0 ORDER BY t0.c2 >= t0.c1 ASC, (-(t0.c0 > t0.c0)) IS NULL ASC. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38634) (comment: 01356_wrong_filter-type_bug.sql) (query 4, line 6) (in query: SELECT t0.c2, t0.c1, t0.c0 FROM t0 PREWHERE t0.c0 ORDER BY ((t0.c2)>=(t0.c1)), (((- (((t0.c0)>(t0.c0))))) IS NULL) FORMAT TabSeparatedWithNamesAndTypes;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002eb21d17 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003054fa9f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:64: DB::validateFilters(std::shared_ptr const&) @ 0x000000003054ecc9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5802: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe18 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:09.623671 [ 10170 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in PREWHERE: String. In query SELECT t0.c2, t0.c1, t0.c0 FROM t0 PREWHERE t0.c0 ORDER BY t0.c2 >= t0.c1 ASC, (-(t0.c0 > t0.c0)) IS NULL ASC. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002eb21d17 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003054fa9f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:64: DB::validateFilters(std::shared_ptr const&) @ 0x000000003054ecc9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5802: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe18 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:09.679913 [ 18771 ] {6c64ef1a-980b-42db-83ae-a1cd5b5d5308} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1197, line 1200) (in query: SELECT sequenceNextNode(NULL, NULL, NULL);) 2025.11.13 09:13:09.691095 [ 18771 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.11.13 09:13:09.710925 [ 18771 ] {9099f532-112a-41d8-8186-a7d9100dffe5} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1198, line 1201) (in query: SELECT seriesDecomposeSTL(NULL, NULL, NULL);) 2025.11.13 09:13:09.721915 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.770783 [ 17383 ] {3d47d611-92ac-45c9-a7f6-85a32ebc1be8} executeQuery: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38732) (comment: 03276_index_empty_part.sql) (query 5, line 10) (in query: DETACH TABLE t_index_empty_part;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d91d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:13:09.776953 [ 17383 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d91d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:13:09.794842 [ 18771 ] {6f4eb925-2140-41c6-91fe-f9395d9a3276} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1200, line 1203) (in query: SELECT seriesPeriodDetectFFT(NULL, NULL, NULL);) 2025.11.13 09:13:09.807278 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.830826 [ 18771 ] {33e98347-bff7-47f3-8e3a-66003d4873da} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1201, line 1204) (in query: SELECT serverTimeZone(NULL, NULL, NULL);) 2025.11.13 09:13:09.837170 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.856260 [ 18771 ] {732133b9-666e-4f11-8455-f966930c646f} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1202, line 1205) (in query: SELECT serverTimezone(NULL, NULL, NULL);) 2025.11.13 09:13:09.867199 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.885334 [ 18771 ] {89c062db-a609-4c1c-93b3-81f61af8d441} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1203, line 1206) (in query: SELECT serverUUID(NULL, NULL, NULL);) 2025.11.13 09:13:09.896377 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.915572 [ 18771 ] {52561c62-d1e2-443e-ac7f-cd3a4019be92} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1204, line 1207) (in query: SELECT shardCount(NULL, NULL, NULL);) 2025.11.13 09:13:09.924939 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.942823 [ 18771 ] {e6d8e649-b993-4e20-8169-bfc10acd7a7d} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1205, line 1208) (in query: SELECT shardNum(NULL, NULL, NULL);) 2025.11.13 09:13:09.951018 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:09.971313 [ 18771 ] {695e64e0-a0d0-4320-840a-9fe2acdbc4d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1206, line 1209) (in query: SELECT showCertificate(NULL, NULL, NULL);) 2025.11.13 09:13:09.976776 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.003548 [ 18771 ] {e46ca550-3436-424d-8dff-4a59010fa71a} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1207, line 1210) (in query: SELECT sigmoid(NULL, NULL, NULL);) 2025.11.13 09:13:10.009423 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.126032 [ 18771 ] {8a6fdf06-00e1-4441-aa99-b098c6962072} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1208, line 1211) (in query: SELECT sign(NULL, NULL, NULL);) 2025.11.13 09:13:10.164685 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.182563 [ 18771 ] {5be5da6e-25d7-4ca4-b8a9-0bfb5c09b889} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1209, line 1212) (in query: SELECT simpleJSONExtractBool(NULL, NULL, NULL);) 2025.11.13 09:13:10.187932 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.207886 [ 18771 ] {c52d74a7-3fc1-4c79-8020-2d6a3cbb56e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1210, line 1213) (in query: SELECT simpleJSONExtractFloat(NULL, NULL, NULL);) 2025.11.13 09:13:10.212488 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.233477 [ 18771 ] {e31c00a8-8743-495f-8009-c6343b8dde45} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1211, line 1214) (in query: SELECT simpleJSONExtractInt(NULL, NULL, NULL);) 2025.11.13 09:13:10.238409 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.258642 [ 18771 ] {28aff922-db5d-4914-83f1-14be454e73d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1212, line 1215) (in query: SELECT simpleJSONExtractRaw(NULL, NULL, NULL);) 2025.11.13 09:13:10.265916 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.319503 [ 18771 ] {e4d8fb9f-1360-4860-9e82-887224938412} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1213, line 1216) (in query: SELECT simpleJSONExtractString(NULL, NULL, NULL);) 2025.11.13 09:13:10.328256 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.347186 [ 18771 ] {6579c562-07a4-43e4-8061-3065c9fe1eca} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1214, line 1217) (in query: SELECT simpleJSONExtractUInt(NULL, NULL, NULL);) 2025.11.13 09:13:10.356869 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.412476 [ 16054 ] {ad13d4a5-fe6b-4b07-b3e8-97cb955e9294} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38730) (comment: 02710_allow_suspicious_indices.sql) (query 2, line 4) (in query: CREATE TABLE tbl (`id` UInt32) ENGINE = MergeTree ORDER BY (id + 1, id + 1) SETTINGS index_granularity = 19259, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 356058274, compact_parts_max_granules_to_buffer = 177, compact_parts_merge_max_bytes_to_prefetch_part = 7739624, merge_max_block_size = 14780, old_parts_lifetime = 346., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 19610358, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 95, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 77111, primary_key_compress_block_size = 89658, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:308: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003987b10b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:728: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039873cb3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003985f7e7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003985c161 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a49609f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a495477 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a487422 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:10.416931 [ 16054 ] {} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:308: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003987b10b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:728: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000039873cb3 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003985f7e7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003985c161 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a49609f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a495477 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a487422 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:10.551591 [ 18771 ] {1cfe8a40-73b5-4f65-abcd-319762b6bddd} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1215, line 1218) (in query: SELECT simpleJSONHas(NULL, NULL, NULL);) 2025.11.13 09:13:10.562034 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.645929 [ 18771 ] {c382f246-209a-429e-ae2f-6f78bdfee337} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1217, line 1220) (in query: SELECT sin(NULL, NULL, NULL);) 2025.11.13 09:13:10.656398 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:10.683959 [ 10170 ] {f8b7b4bc-e4c5-4bb0-890f-edd0ee8c64f1} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT t0.c2, t0.c1, t0.c0 FROM t0 WHERE t0.c0 ORDER BY t0.c2 >= t0.c1 ASC, (-(t0.c0 > t0.c0)) IS NULL ASC. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38634) (comment: 01356_wrong_filter-type_bug.sql) (query 5, line 7) (in query: SELECT t0.c2, t0.c1, t0.c0 FROM t0 WHERE t0.c0 ORDER BY ((t0.c2)>=(t0.c1)), (((- (((t0.c0)>(t0.c0))))) IS NULL) FORMAT TabSeparatedWithNamesAndTypes settings optimize_move_to_prewhere=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002eb21d17 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003054fa9f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000003054ee63 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5802: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe18 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:10.688412 [ 10170 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT t0.c2, t0.c1, t0.c0 FROM t0 WHERE t0.c0 ORDER BY t0.c2 >= t0.c1 ASC, (-(t0.c0 > t0.c0)) IS NULL ASC. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002eb21d17 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003054fa9f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:74: DB::validateFilters(std::shared_ptr const&) @ 0x000000003054ee63 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5802: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe18 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:10.834548 [ 18771 ] {26489da8-68e3-413b-8713-c78569e26280} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1219, line 1222) (in query: SELECT sinh(NULL, NULL, NULL);) 2025.11.13 09:13:10.845927 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:11.357534 [ 18771 ] {5a5a0e6d-122b-44bf-896d-f622ecfcaafc} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1228, line 1231) (in query: SELECT sleep(NULL, NULL, NULL);) 2025.11.13 09:13:11.366062 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:11.404482 [ 18771 ] {d916d025-2eeb-42ab-83e0-6e268a5a2f01} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1229, line 1232) (in query: SELECT sleepEachRow(NULL, NULL, NULL);) 2025.11.13 09:13:11.414747 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:11.566090 [ 16054 ] {86abe283-205b-4fb8-95b8-9456ddd3aac1} executeQuery: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38730) (comment: 02710_allow_suspicious_indices.sql) (query 5, line 8) (in query: CREATE TABLE tbl (`id` UInt32, INDEX idx (id + 1, id + 1) TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 19259, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 356058274, compact_parts_max_granules_to_buffer = 177, compact_parts_merge_max_bytes_to_prefetch_part = 7739624, merge_max_block_size = 14780, old_parts_lifetime = 346., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 19610358, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 95, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 77111, primary_key_compress_block_size = 89658, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:308: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003987b10b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:804: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000398772f8 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003985f7e7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003985c161 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a49609f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a495477 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a487422 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:11.570355 [ 16054 ] {} TCPHandler: Code: 36. DB::Exception: Primary key or secondary index contains a duplicate expression. To suppress this exception, rerun the command with setting 'allow_suspicious_indices = 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:308: DB::checkSuspiciousIndices(DB::ASTFunction const*) @ 0x000000003987b10b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:804: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x00000000398772f8 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000003985f7e7 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:515: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003985c161 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a49609f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a495477 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a487422 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:11.695375 [ 16054 ] {5f1d12b3-aad1-4e15-b992-a3badddb6258} executeQuery: Code: 57. DB::Exception: Table test_3.tbl already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38730) (comment: 02710_allow_suspicious_indices.sql) (query 8, line 14) (in query: CREATE TABLE tbl (`id1` UInt32) ENGINE = MergeTree ORDER BY id1 SETTINGS index_granularity = 19259, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 356058274, compact_parts_max_granules_to_buffer = 177, compact_parts_merge_max_bytes_to_prefetch_part = 7739624, merge_max_block_size = 14780, old_parts_lifetime = 346., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 19610358, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 95, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 77111, primary_key_compress_block_size = 89658, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:11.699835 [ 16054 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.tbl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:11.756079 [ 18771 ] {0a6585b0-be3a-4df3-9126-d47039a0c858} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1234, line 1237) (in query: SELECT soundex(NULL, NULL, NULL);) 2025.11.13 09:13:11.765938 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:11.785256 [ 18771 ] {dd229638-74df-44b0-a091-a1e1548c2ffa} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1235, line 1238) (in query: SELECT space(NULL, NULL, NULL);) 2025.11.13 09:13:11.805347 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:12.568795 [ 18771 ] {df77ffa4-235b-40a3-b90c-92f0b2a2290f} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1245, line 1248) (in query: SELECT sqidDecode(NULL, NULL, NULL);) 2025.11.13 09:13:12.574499 [ 19499 ] {77eaba82-852e-469c-b096-b9ff4ccc495e} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52786) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (query 7, line 22) (in query: ALTER TABLE replicated_table_for_alter1 MODIFY SETTING index_granularity = 4096;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3943: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000399233b1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:12.574607 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:12.577989 [ 19499 ] {} TCPHandler: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3943: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000399233b1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:12.684564 [ 18771 ] {31c1781b-e96a-4d0c-bf4d-11a3952c594c} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1247, line 1250) (in query: SELECT sqrt(NULL, NULL, NULL);) 2025.11.13 09:13:12.692286 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:12.762173 [ 16690 ] {51264c99-0d7b-4ade-af03-8a53f0fde9ad} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 14, line 16) (in query: select makeDate(cast(1980 as Date), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:12.775717 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:12.779135 [ 18771 ] {fc9683ca-d248-439d-8b85-697e7ae08ff4} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1248, line 1251) (in query: SELECT startsWith(NULL, NULL, NULL);) 2025.11.13 09:13:12.788558 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:12.805630 [ 18771 ] {ee3c1353-b60a-4949-b39b-1318508c424f} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1249, line 1252) (in query: SELECT startsWithUTF8(NULL, NULL, NULL);) 2025.11.13 09:13:12.815479 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:12.865953 [ 16690 ] {9cd4e8a5-31ee-4376-83ed-7249b6929bd4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 15, line 17) (in query: select makeDate(cast(-1980 as Date), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:12.870036 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date: In scope SELECT makeDate(CAST(-1980, 'Date'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:12.917272 [ 16690 ] {08ef191d-28dc-485b-aba6-e7bf002b4d22} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 16, line 18) (in query: select makeDate(cast(1980 as Date32), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:12.921338 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.027432 [ 16690 ] {7e4a2561-3f86-4eed-af3e-a1f2f585c69f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 17, line 19) (in query: select makeDate(cast(-1980 as Date32), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.031364 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Date32: In scope SELECT makeDate(CAST(-1980, 'Date32'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.054726 [ 16690 ] {b13dd948-0e01-46ce-9794-78de9b730d30} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 18, line 20) (in query: select makeDate(cast(1980 as DateTime), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.058580 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.060707 [ 18771 ] {4d33de65-54ea-4671-ab75-1505ae576fd2} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1254, line 1257) (in query: SELECT stem(NULL, NULL, NULL);) 2025.11.13 09:13:13.067580 [ 18771 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:13:13.079372 [ 16690 ] {0796264a-06d9-4235-976c-952c82713967} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 19, line 21) (in query: select makeDate(cast(-1980 as DateTime), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.086940 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime: In scope SELECT makeDate(CAST(-1980, 'DateTime'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.111988 [ 16690 ] {31ad5f22-af5f-4991-9e57-80ae73a26f77} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 20, line 22) (in query: select makeDate(cast(1980 as DateTime64), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.115701 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.137046 [ 16690 ] {7316fac9-0b98-4271-878d-71f19ae22e7b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 21, line 23) (in query: select makeDate(cast(-1980 as DateTime64), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.189777 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate(CAST(-1980, 'DateTime64'), 10). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.210183 [ 16690 ] {e225562d-7ebe-4d59-9a9b-b9cfc4524746} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 22, line 24) (in query: select makeDate('1980', '10');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.213988 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('1980', '10'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.234526 [ 16690 ] {6901b76d-91e2-4c77-b1f0-6682f3136422} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 23, line 25) (in query: select makeDate('-1980', 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.238527 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('-1980', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.258825 [ 16690 ] {b7b1f194-229e-4aaa-9cc6-525c31e9a1e6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 24, line 26) (in query: select makeDate('aa', 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.262916 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate('aa', 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.281172 [ 16690 ] {6f398315-6f80-4e94-ae0c-1555b9ee91a0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52762) (comment: 02242_make_date_mysql.sql) (query 25, line 27) (in query: select makeDate(1994, 'aa');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.284961 [ 16690 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'dayofyear' to function 'makeDate'. Expected: Number, got: String: In scope SELECT makeDate(1994, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475530f 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:13.667636 [ 17653 ] {3254c9ff-a844-45ac-908b-864c783e61b7} executeQuery: Code: 6. DB::Exception: Illegal character '\x0d' in partition id starting with 'test_'. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52830) (comment: 01944_insert_partition_by.sql) (query 1, line 4) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000383ece4d 4. ./build_docker/./src/Storages/PartitionedSink.cpp:137: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000383e9fd5 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:158: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d577f35 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 7. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 8. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:13.684720 [ 17653 ] {} TCPHandler: Code: 6. DB::Exception: Illegal character '\x0d' in partition id starting with 'test_'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000383ece4d 4. ./build_docker/./src/Storages/PartitionedSink.cpp:137: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000383e9fd5 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:158: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d577f35 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 7. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 8. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:13.705739 [ 18771 ] {557f06a4-fa34-453f-b70d-35016d7581c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1259, line 1262) (in query: SELECT stringJaccardIndex(NULL, NULL, NULL);) 2025.11.13 09:13:13.713299 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:13.736553 [ 18771 ] {a8129791-f660-4d0f-9bda-a647908fede5} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1260, line 1263) (in query: SELECT stringJaccardIndexUTF8(NULL, NULL, NULL);) 2025.11.13 09:13:13.737851 [ 17653 ] {51aba3ba-5fd8-4a73-b298-17a366e70803} executeQuery: Code: 6. DB::Exception: Illegal character '\x00' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52830) (comment: 01944_insert_partition_by.sql) (query 2, line 5) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000383ece4d 4. ./build_docker/./src/Storages/PartitionedSink.cpp:137: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000383e9fd5 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:158: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d577f35 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 7. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 8. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:13.746246 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:13.749247 [ 17653 ] {} TCPHandler: Code: 6. DB::Exception: Illegal character '\x00' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000383ece4d 4. ./build_docker/./src/Storages/PartitionedSink.cpp:137: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000383e9fd5 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:158: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d577f35 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 7. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 8. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:13.766278 [ 18771 ] {540a59ec-3619-483a-8900-773e237186fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1261, line 1264) (in query: SELECT stringToH3(NULL, NULL, NULL);) 2025.11.13 09:13:13.794176 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:13.815392 [ 18771 ] {249a7665-c058-474f-bd83-cb869dc53eb1} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1262, line 1265) (in query: SELECT structureToCapnProtoSchema(NULL, NULL, NULL);) 2025.11.13 09:13:13.824300 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:13.845497 [ 18771 ] {65387de1-1fbc-4daa-97ba-262d3f48c39b} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1263, line 1266) (in query: SELECT structureToProtobufSchema(NULL, NULL, NULL);) 2025.11.13 09:13:13.850634 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:14.068605 [ 18771 ] {9f3e47ee-4df1-4c44-a956-739614593720} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1266, line 1269) (in query: SELECT subDate(NULL, NULL, NULL);) 2025.11.13 09:13:14.096949 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:14.777991 [ 18771 ] {59074d80-04b6-4f51-9481-8c91e0400f7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1274, line 1277) (in query: SELECT subtractInterval(NULL, NULL, NULL);) 2025.11.13 09:13:14.787671 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:15.141558 [ 16235 ] {60b5d4b1-a6b3-4d01-8561-bf2274a211a2} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38604) (comment: 00930_max_partitions_per_insert_block.sql) (query 9, line 12) (in query: INSERT INTO partitions SELECT * FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:119: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7dcd5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:13:15.148469 [ 16235 ] {} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000d138aea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:119: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7dcd5 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:13:15.265538 [ 18771 ] {962d92e7-320b-4abb-bcb8-38c2fa12d204} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1282, line 1285) (in query: SELECT subtractTupleOfIntervals(NULL, NULL, NULL);) 2025.11.13 09:13:15.273129 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:15.654420 [ 17653 ] {3aadb97b-ce64-4dff-bb5a-1e37ad3c3959} executeQuery: Code: 6. DB::Exception: Incorrect non-UTF8 sequence in key. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52830) (comment: 01944_insert_partition_by.sql) (query 3, line 6) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:156: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d57826b 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 6. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 7. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:15.732856 [ 17653 ] {} TCPHandler: Code: 6. DB::Exception: Incorrect non-UTF8 sequence in key. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:156: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d57826b 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 6. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 7. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:15.867691 [ 17653 ] {01e9793a-3f27-40e3-a4ad-03fbb57ca246} executeQuery: Code: 6. DB::Exception: Illegal character '\x7d' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52830) (comment: 01944_insert_partition_by.sql) (query 4, line 7) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000383ece4d 4. ./build_docker/./src/Storages/PartitionedSink.cpp:137: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000383e9fd5 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:158: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d577f35 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 7. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 8. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:15.878579 [ 17653 ] {} TCPHandler: Code: 6. DB::Exception: Illegal character '\x7d' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000383ece4d 4. ./build_docker/./src/Storages/PartitionedSink.cpp:137: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000383e9fd5 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:158: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d577f35 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 7. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 8. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:16.026469 [ 17653 ] {0350e579-a49e-4fb6-9dd4-49c86079ad11} executeQuery: Code: 6. DB::Exception: Illegal character '\x2a' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52830) (comment: 01944_insert_partition_by.sql) (query 5, line 8) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000383ece4d 4. ./build_docker/./src/Storages/PartitionedSink.cpp:137: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000383e9fd5 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:158: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d577f35 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 7. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 8. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:16.057729 [ 17653 ] {} TCPHandler: Code: 6. DB::Exception: Illegal character '\x2a' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000383ece4d 4. ./build_docker/./src/Storages/PartitionedSink.cpp:137: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000383e9fd5 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:158: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d577f35 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 7. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 8. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:16.080857 [ 19499 ] {01a9f43e-7265-4342-ac59-4c5de9940bf2} executeQuery: Code: 252. DB::Exception: Too many parts (2 with average size of 327.00 B) in table 'test_2fch3ouh.replicated_table_for_alter2 (19b931dc-7298-454c-a33e-1062ee6171c5)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52786) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (query 23, line 49) (in query: INSERT INTO replicated_table_for_alter2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000039a94997 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4991: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e777 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1219: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x000000003a3c0c80 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000003b217963 13. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed0f77 14. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:13:16.086007 [ 19499 ] {} TCPHandler: Code: 252. DB::Exception: Too many parts (2 with average size of 327.00 B) in table 'test_2fch3ouh.replicated_table_for_alter2 (19b931dc-7298-454c-a33e-1062ee6171c5)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000039a94997 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4991: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e777 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1219: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x000000003a3c0c80 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000003b217963 13. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed0f77 14. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:13:16.379520 [ 18771 ] {3fd73ba8-7d32-416f-b5d6-fb0f046ad3fb} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1294, line 1297) (in query: SELECT synonyms(NULL, NULL, NULL);) 2025.11.13 09:13:16.385183 [ 18771 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:13:16.435903 [ 18771 ] {e4314ee5-299f-4298-9eeb-db043726ab20} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1295, line 1298) (in query: SELECT tan(NULL, NULL, NULL);) 2025.11.13 09:13:16.471397 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:16.496996 [ 18771 ] {af487971-cdcf-41f5-8750-49e22dd3942a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1296, line 1299) (in query: SELECT tanh(NULL, NULL, NULL);) 2025.11.13 09:13:16.506315 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:16.565825 [ 18771 ] {4e72a943-cd4e-4265-b91d-0516054f3dbf} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1297, line 1300) (in query: SELECT tcpPort(NULL, NULL, NULL);) 2025.11.13 09:13:16.577905 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:16.597417 [ 18771 ] {202c0e01-65fc-42ea-90c8-096520ce8020} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1298, line 1301) (in query: SELECT test_function(NULL, NULL, NULL);) 2025.11.13 09:13:16.673370 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:16.716337 [ 18771 ] {54db5290-4d92-4a20-b4a2-194b13a0effd} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1299, line 1302) (in query: SELECT tgamma(NULL, NULL, NULL);) 2025.11.13 09:13:16.722519 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:16.957618 [ 18771 ] {f23020cd-e33c-408b-984b-2c404105b9a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1302, line 1305) (in query: SELECT tid(NULL, NULL, NULL);) 2025.11.13 09:13:16.965310 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:17.045553 [ 18771 ] {e04fc292-1436-43e3-be8b-ecf7ef600768} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1303, line 1306) (in query: SELECT timeDiff(NULL, NULL, NULL);) 2025.11.13 09:13:17.052152 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:17.151437 [ 18771 ] {5b3a0267-d9e7-4036-bb15-514a02ba843d} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1306, line 1309) (in query: SELECT timeZone(NULL, NULL, NULL);) 2025.11.13 09:13:17.157153 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:17.180007 [ 18771 ] {9b4d95f5-5fe4-4e0d-88e1-c3a9615e11fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1307, line 1310) (in query: SELECT timeZoneOf(NULL, NULL, NULL);) 2025.11.13 09:13:17.184891 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:17.269051 [ 19243 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:13:17.269583 [ 19243 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:13:17.407490 [ 19620 ] {85e64823-22ec-41c7-ad37-8c47ebcfdfc1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55540) (comment: 02969_functions_to_subcolumns_if_null.sql) (in query: DROP DATABASE IF EXISTS test_ftp9f3ib SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:13:17.411210 [ 19620 ] {85e64823-22ec-41c7-ad37-8c47ebcfdfc1} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:17.536597 [ 18771 ] {f946566c-6a47-4630-a678-0676c236ab89} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1313, line 1316) (in query: SELECT timezone(NULL, NULL, NULL);) 2025.11.13 09:13:17.541763 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:17.561875 [ 18771 ] {2e2fd1b8-3acf-4cd2-b8d4-f94400339e8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1314, line 1317) (in query: SELECT timezoneOf(NULL, NULL, NULL);) 2025.11.13 09:13:17.569263 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:17.690161 [ 16194 ] {f717ad9d-c5f1-4719-b9ce-b4ffc0686270} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 100). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53006) (comment: 01428_h3_range_check.sql) (query 1, line 3) (in query: SELECT h3ToChildren(599405990164561919, 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::(anonymous namespace)::FunctionH3ToChildren::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001163e066 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:13:17.694965 [ 16194 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToChildren is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToChildren(599405990164561919, 100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::(anonymous namespace)::FunctionH3ToChildren::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001163e066 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:13:17.853340 [ 19618 ] {d234754a-8ac1-488e-95fd-b5dbb18fbcd6} executeQuery: Code: 131. DB::Exception: Too large string size: 18446744073709551615. The maximum is: 17179869184.: While executing Native. (TOO_LARGE_STRING_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53052) (comment: 02683_native_too_large_size.sql) (query 1, line 1) (in query: SELECT * FROM format('Native', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int32, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, VindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$i WatchIDInt64c*5/ !p~ úFÚÓ“2ql!è–|¨@H²Ç=ÐŒWéòˆE&Ly¹ãk=÷±pæ1þž oíC»-ÞC_ìÒŒ\Û/E‚ÜJÛ{ JavaEnableInt16TitleString GoodEventInt16 EventTimeDateTime7ðâQn$äQÃ)äQ8*äQJîâQÉ ãQµ0äQ83äQ× äQÖ1ãQ EventDateDate>>>>>>>>>> CounterIDInt32ClientIPInt32®Æz·®Æz·®Æz·®Æz·º‹I`®Æz·É^{]É^{]gU®Æz·RegionIDInt32GGGG'GÅÅåGUserIDInt64× ’•:6×Ý× ’•:6×Ý× ’•:6×Ý× ’•:6×Ýq—íJd8 ÎKs}¡ï&n%Št"6&n%Št"6ƒs—yyçóf× ’•:6×Ý CounterClassInt16OSInt16'', UserAgentInt16URLString-http://holodilInt16WindowClientWidthInt16WindowClientHeightInt16ClientTimeZoneInt16ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿClientEventTimeDateTimeîáîáîáîáîáîáîáîáîáîáSilverlightVersion1Int16SilverlightVersion2Int16SilverlightVersion3Int32SilverlightVersion4Int16 PageCharsetString CodeVersionInt32IsLinkInt16 IsDownloadInt16 IsNotBounceInt16FUniqIDInt64%œlû©+k:¤ìWëÂm OriginalURLStringHIDInt32 IsOldCounterInt16IsEventInt16 IsParameterInt16 DontCountHitsInt16WithHashInt16HitColorString5555555555LocalEventTimeDateTime&·ãQǘãQ}žãQÝžãQ'¡ãQA¶ãQ¼£ãQ ¦ãQY’ãQ‹ÏãQAgeInt16SexInt16IncomeInt16 InterestsInt16¦: RobotnessInt16RemoteIPInt32^DIÄ^DIÄ^DIÄ^DIÄ9ê3N^DIÄ…U…U€=k^DIÄ WindowNameInt32ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿ OpenerNameInt32ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿ HistoryLengthInt16ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿBrowserLanguageString����������BrowserCountryString� � � � � � � � � � SocialNetworkString SocialActionString HTTPErrorInt16 SendTimingInt32 DNSTimingInt32 ConnectTimingInt32ResponseStartTimingInt32ResponseEndTimingInt32 FetchTimingInt32SocialSourceNetworkIDInt16SocialSourcePageString ParamPriceInt64 ParamOrderIDString ParamCurrencyStringNHNHNHNHNHNHNHNHNHNHParamCurrencyIDInt16OpenstatServiceNameStringOpenstatCampaignIDString OpenstatAdIDStringOpenstatSourceIDString UTMSourceString UTMMediumString UTMCampaignString UTMContentStringUTMTermStringFromTagStringHasGCLIDInt16 RefererHashInt64X+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûURLHashInt64Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Ž oâïòeý€ à#â\X-h³ýX vÀvÍÀ‰Çh˜´9›DÍ|3úÐb.‹CLIDInt32$$);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b2043ed 4. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:168: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bfcbc 5. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 6. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 7. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003b0c9858 8. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:44: DB::NativeInputFormat::read() @ 0x000000003b668414 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 19. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:13:17.857687 [ 19618 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size: 18446744073709551615. The maximum is: 17179869184.: While executing Native. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b2043ed 4. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:168: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bfcbc 5. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 6. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 7. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003b0c9858 8. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:44: DB::NativeInputFormat::read() @ 0x000000003b668414 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 19. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:13:17.988520 [ 18771 ] {3b08f261-7aa4-4129-a60c-b69fb714d42b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1319, line 1322) (in query: SELECT toBool(NULL, NULL, NULL);) 2025.11.13 09:13:17.994829 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:18.016152 [ 18771 ] {224b5550-75b4-4c4e-8786-74e8485ba2a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1320, line 1323) (in query: SELECT toColumnTypeName(NULL, NULL, NULL);) 2025.11.13 09:13:18.020505 [ 17653 ] {37734c76-daf4-49dd-ac34-892260632e49} executeQuery: Code: 36. DB::Exception: Incorrect key length (not empty, max 1023 characters), got: 0. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52830) (comment: 01944_insert_partition_by.sql) (query 6, line 9) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/{_partition_id}', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000cd8388a 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d57811f 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 6. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 7. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:18.021749 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:18.032791 [ 17653 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect key length (not empty, max 1023 characters), got: 0. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000cd8388a 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x000000002d57811f 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:128: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57736b 6. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 7. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 16. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 17. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:18.160983 [ 18771 ] {82db3ea6-9e1b-4c82-bae1-ada56b218ef0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1323, line 1326) (in query: SELECT toDate32OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:18.167307 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:18.284850 [ 18771 ] {9ecf23d4-44eb-4bc8-8e02-db5dc253966d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1326, line 1329) (in query: SELECT toDateOrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:18.377407 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:18.880683 [ 18771 ] {1933ede1-47a2-4b44-9203-d96aeab2ce97} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1332, line 1335) (in query: SELECT toDateTime64OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:18.886454 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDateTime64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:18.915032 [ 16194 ] {f09780ea-f3dd-433d-9800-98da324be7ad} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToParent is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToParent(599405990164561919, 100). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53006) (comment: 01428_h3_range_check.sql) (query 2, line 4) (in query: SELECT h3ToParent(599405990164561919, 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::(anonymous namespace)::FunctionH3ToParent::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011647cf7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:13:18.919234 [ 16194 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3ToParent is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3ToParent(599405990164561919, 100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::(anonymous namespace)::FunctionH3ToParent::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011647cf7 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:13:19.135083 [ 19499 ] {de6cfa1c-4f50-46c2-9e85-f78f0191d64d} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52786) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (query 46, line 93) (in query: ALTER TABLE replicated_table_for_reset_setting1 MODIFY SETTING index_granularity = 4096;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3943: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000399233b1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:19.139020 [ 18771 ] {42da92b4-425e-426c-b6bd-988b1081f74f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1335, line 1338) (in query: SELECT toDateTimeOrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:19.139163 [ 19499 ] {} TCPHandler: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3943: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000399233b1 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:19.144664 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Nullable(Nothing): In scope SELECT toDateTimeOrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:19.251840 [ 19187 ] {17ae97dd-8f86-4397-969a-d6740e578c46} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.name, 'all_0_5_1_6'_String) :: 2) -> throwIf(equals(__table1.name, 'all_0_5_1_6'_String)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52868) (comment: 02446_parent_zero_copy_locks.sql) (query 12, line 26) (in query: -- wait for parts to be merged select throwIf(name = 'all_0_5_1_6') from system.parts where database=currentDatabase() and table like 'rmt%' and active format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:13:19.257142 [ 19187 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.name, 'all_0_5_1_6'_String) :: 2) -> throwIf(equals(__table1.name, 'all_0_5_1_6'_String)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:13:19.779581 [ 17653 ] {c790e0d2-3853-427c-891d-8264b358634f} executeQuery: Code: 36. DB::Exception: Bucket name length is out of bounds in virtual hosted style S3 URI: ''. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52830) (comment: 01944_insert_partition_by.sql) (query 7, line 10) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/{_partition_id}/key.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/IO/S3/URI.cpp:171: DB::S3::URI::validateBucket(String const&, Poco::URI const&) @ 0x000000002d69daa5 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::validateNamespace(String const&) const @ 0x000000002d67760e 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:163: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x000000002d577b33 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57721d 8. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 9. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 18. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 19. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:13:19.881995 [ 17653 ] {} TCPHandler: Code: 36. DB::Exception: Bucket name length is out of bounds in virtual hosted style S3 URI: ''. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/IO/S3/URI.cpp:171: DB::S3::URI::validateBucket(String const&, Poco::URI const&) @ 0x000000002d69daa5 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:103: DB::StorageS3Configuration::validateNamespace(String const&) const @ 0x000000002d67760e 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:163: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x000000002d577b33 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57721d 8. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 9. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 13. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 18. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 19. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:13:19.891630 [ 18771 ] {b98d9ab2-e176-424d-8ec1-16edd132c420} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1343, line 1346) (in query: SELECT toDecimal128OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:19.902967 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal128OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:19.992621 [ 19619 ] {fca3206c-aee6-47d8-af20-3a0acc5c8183} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 5, line 6) (in query: SELECT snowflakeIDToDateTime();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:13:20.019033 [ 19619 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:13:20.122091 [ 18771 ] {1223a5f3-b3bf-48c4-8865-ed5808f21cf7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1347, line 1350) (in query: SELECT toDecimal256OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:20.128720 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal256OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:20.295256 [ 18771 ] {185dc266-eec7-4a84-b5ac-75bbbbdb8267} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1351, line 1354) (in query: SELECT toDecimal32OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:20.300757 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal32OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:20.472211 [ 18771 ] {55798b27-6b00-4b83-b00c-50cd35788d97} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1355, line 1358) (in query: SELECT toDecimal64OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:20.478483 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Nullable(Nothing): In scope SELECT toDecimal64OrDefault(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:20.730157 [ 18771 ] {6a12629d-c913-426f-a0fb-17152d69a048} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1358, line 1361) (in query: SELECT toDecimalString(NULL, NULL, NULL);) 2025.11.13 09:13:20.834289 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:20.904172 [ 18771 ] {b3b9522f-0b54-4bf5-92bf-6f8b32e91e4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1359, line 1362) (in query: SELECT toFixedString(NULL, NULL, NULL);) 2025.11.13 09:13:20.913533 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:20.962061 [ 19499 ] {0a974de6-dfac-48e8-a506-07b17595584e} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'unknown_setting' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52786) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (query 58, line 112) (in query: -- don't execute alter with incorrect setting ALTER TABLE replicated_table_for_reset_setting1 RESET SETTING check_delay_period, unknown_setting;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922b6d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:20.965933 [ 19499 ] {} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'unknown_setting' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3833: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039922b6d 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:20.979434 [ 18771 ] {9626930f-19ee-4721-8596-83122b88c2f3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1361, line 1364) (in query: SELECT toFloat32OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:20.985301 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:21.186850 [ 16390 ] {208c506f-3bcc-4f5e-be2b-9ccf2ff8803c} executeQuery: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('abc', 3, ['a1c']) FROM system.numbers LIMIT 3. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53120) (comment: 00929_multi_match_edit_distance.sql) (query 6, line 11) (in query: select multiFuzzyMatchAny('abc', 3, ['a1c']) from system.numbers limit 3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x0000000016c5f63f 5. DB::MultiRegexps::Regexps std::__function::__policy_invoker::__call_impl[abi:ne190107] DB::MultiRegexps::getOrSet(std::vector>, std::allocator>>> const&, std::optional)::'lambda'(), DB::MultiRegexps::Regexps ()>>(std::__function::__policy_storage const*) @ 0x0000000016c5dfa2 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x0000000016c4965b 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c56b8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:13:21.240796 [ 16390 ] {} TCPHandler: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('abc', 3, ['a1c']) FROM system.numbers LIMIT 3. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x0000000016c5f63f 5. DB::MultiRegexps::Regexps std::__function::__policy_invoker::__call_impl[abi:ne190107] DB::MultiRegexps::getOrSet(std::vector>, std::allocator>>> const&, std::optional)::'lambda'(), DB::MultiRegexps::Regexps ()>>(std::__function::__policy_storage const*) @ 0x0000000016c5dfa2 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x0000000016c4965b 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c56b8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:13:21.273713 [ 16390 ] {80cd74b0-7a9e-4767-af90-a88519d8bdbd} executeQuery: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('abc', 4, ['a1c']) FROM system.numbers LIMIT 3. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53120) (comment: 00929_multi_match_edit_distance.sql) (query 7, line 12) (in query: select multiFuzzyMatchAny('abc', 4, ['a1c']) from system.numbers limit 3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x0000000016c5f63f 5. DB::MultiRegexps::Regexps std::__function::__policy_invoker::__call_impl[abi:ne190107] DB::MultiRegexps::getOrSet(std::vector>, std::allocator>>> const&, std::optional)::'lambda'(), DB::MultiRegexps::Regexps ()>>(std::__function::__policy_storage const*) @ 0x0000000016c5dfa2 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x0000000016c4965b 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c56b8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:13:21.278653 [ 16390 ] {} TCPHandler: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('abc', 4, ['a1c']) FROM system.numbers LIMIT 3. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x0000000016c5f63f 5. DB::MultiRegexps::Regexps std::__function::__policy_invoker::__call_impl[abi:ne190107] DB::MultiRegexps::getOrSet(std::vector>, std::allocator>>> const&, std::optional)::'lambda'(), DB::MultiRegexps::Regexps ()>>(std::__function::__policy_storage const*) @ 0x0000000016c5dfa2 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x0000000016c4965b 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c56b8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:13:21.309235 [ 18771 ] {c348f1e8-4263-45be-bccf-acec2b05dcdc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1365, line 1368) (in query: SELECT toFloat64OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:21.314736 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:21.358166 [ 19619 ] {520899eb-9946-421f-80d7-79048f4720cb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 6, line 7) (in query: SELECT snowflakeIDToDateTime64();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:13:21.362303 [ 19619 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:13:21.395533 [ 17653 ] {9d4c9ffa-c995-4c68-bc73-275291411df9} executeQuery: Code: 6. DB::Exception: Illegal character '\x2f' in partition id starting with 'aa'. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52830) (comment: 01944_insert_partition_by.sql) (query 8, line 11) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/{_partition_id}/key.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000383ece4d 4. ./build_docker/./src/Storages/PartitionedSink.cpp:137: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000383e9fd5 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:168: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x000000002d577bc5 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57721d 7. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 8. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:21.407529 [ 17653 ] {} TCPHandler: Code: 6. DB::Exception: Illegal character '\x2f' in partition id starting with 'aa'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x00000000383ece4d 4. ./build_docker/./src/Storages/PartitionedSink.cpp:137: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x00000000383e9fd5 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:168: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x000000002d577bc5 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x000000002d57721d 7. ./build_docker/./src/Storages/PartitionedSink.cpp:48: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x00000000383e2f6f 8. ./build_docker/./src/Storages/PartitionedSink.cpp:107: DB::PartitionedSink::consume(DB::Chunk&) @ 0x00000000383e7ce9 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:13:21.575556 [ 18771 ] {18299745-d33f-40a9-99b1-62391de49f75} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1370, line 1373) (in query: SELECT toIPv4OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:21.582313 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:21.880104 [ 18771 ] {6a10b5aa-4696-49aa-b67a-75e9afd86199} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1374, line 1377) (in query: SELECT toIPv6OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:21.922327 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:22.450273 [ 18771 ] {8a819351-31da-4dd5-a268-cfc57a2bf840} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1380, line 1383) (in query: SELECT toInt128OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:22.461012 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:22.714429 [ 18771 ] {7f3c3079-a7a4-4573-82a5-4cf7992f28fd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1384, line 1387) (in query: SELECT toInt16OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:22.723963 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:22.756736 [ 19619 ] {3858718f-e6bd-4a95-8322-563d52485286} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 7, line 8) (in query: SELECT snowflakeIDToDateTime('invalid_snowflake');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:22.761317 [ 19619 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:22.796673 [ 19243 ] {d983cdad-e6ca-40c1-b865-47126fcfec01} executeQuery: Code: 420. DB::Exception: Updated column `t` affects MATERIALIZED column `a`, which is a key column. Cannot UPDATE it. (CANNOT_UPDATE_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53084) (comment: 03596_alter_update_column_with_subcolumn_used_in_materialized_expression.sql) (query 22, line 25) (in query: alter table test update t = tuple(2) where 1 settings mutations_sync=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:512: DB::MutationsInterpreter::prepare(bool) @ 0x0000000032ede4f4 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:406: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000032ec13e5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991bf5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:13:22.800717 [ 19243 ] {} TCPHandler: Code: 420. DB::Exception: Updated column `t` affects MATERIALIZED column `a`, which is a key column. Cannot UPDATE it. (CANNOT_UPDATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:512: DB::MutationsInterpreter::prepare(bool) @ 0x0000000032ede4f4 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:406: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000032ec13e5 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991bf5 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:13:23.081198 [ 18771 ] {2daf1d3b-15c1-4ae9-a5ae-354d4b9bdf27} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1388, line 1391) (in query: SELECT toInt256OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:23.087557 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:23.574552 [ 18771 ] {803a27b6-ea0b-458b-a6e2-26b934f028b9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1392, line 1395) (in query: SELECT toInt32OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:23.584474 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:23.808832 [ 19187 ] {4117b080-544c-4a61-809b-dd88c2b96a74} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(count(), 0_UInt8) :: 1) -> throwIf(equals(count(), 0_UInt8)) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52868) (comment: 02446_parent_zero_copy_locks.sql) (query 20, line 39) (in query: -- wait for outdated parts to be removed (do not ignore _state column, so it will count Deleting parts as well) select throwIf(count() = 0), groupArray(_state) from ( select *, _state from system.parts where database=currentDatabase() and table like 'rmt%' and active=0 ) format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:13:23.816887 [ 19187 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(count(), 0_UInt8) :: 1) -> throwIf(equals(count(), 0_UInt8)) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:13:23.907218 [ 18771 ] {7670fed0-1ade-4e1e-8c46-a711b8c9a29b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1396, line 1399) (in query: SELECT toInt64OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:23.916092 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:24.032413 [ 19619 ] {8ebbe2d5-6dd6-462a-ac3c-335b1e61db90} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime64('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 8, line 9) (in query: SELECT snowflakeIDToDateTime64('invalid_snowflake');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:24.072612 [ 18771 ] {2de04ad4-0d8d-4e29-b649-c2f05f181147} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1400, line 1403) (in query: SELECT toInt8OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:24.075076 [ 19619 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime64('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:24.079645 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:24.610302 [ 16390 ] {b022d747-2a0f-4fed-aef6-e2abef2643d6} executeQuery: Code: 36. DB::Exception: Pattern '^hello.*world$' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('hello some world', 10, ['^hello.*world$']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53120) (comment: 00929_multi_match_edit_distance.sql) (query 15, line 22) (in query: select multiFuzzyMatchAny('hello some world', 10, ['^hello.*world$']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x0000000016c5f63f 5. DB::MultiRegexps::Regexps std::__function::__policy_invoker::__call_impl[abi:ne190107] DB::MultiRegexps::getOrSet(std::vector>, std::allocator>>> const&, std::optional)::'lambda'(), DB::MultiRegexps::Regexps ()>>(std::__function::__policy_storage const*) @ 0x0000000016c5dfa2 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x0000000016c4965b 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c56b8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:13:24.615270 [ 16390 ] {} TCPHandler: Code: 36. DB::Exception: Pattern '^hello.*world$' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': In scope SELECT multiFuzzyMatchAny('hello some world', 10, ['^hello.*world$']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x0000000016c5f63f 5. DB::MultiRegexps::Regexps std::__function::__policy_invoker::__call_impl[abi:ne190107] DB::MultiRegexps::getOrSet(std::vector>, std::allocator>>> const&, std::optional)::'lambda'(), DB::MultiRegexps::Regexps ()>>(std::__function::__policy_storage const*) @ 0x0000000016c5dfa2 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x0000000016c4965b 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c56b8f 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:13:24.961098 [ 18771 ] {324b2093-3745-4550-a1d8-a7bb3ddd29b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1414, line 1417) (in query: SELECT toJSONString(NULL, NULL, NULL);) 2025.11.13 09:13:24.969489 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:25.098641 [ 18771 ] {f0b4bfdf-dd3e-49db-9446-7a7d5ea59567} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1417, line 1420) (in query: SELECT toLowCardinality(NULL, NULL, NULL);) 2025.11.13 09:13:25.106182 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:25.221013 [ 18771 ] {a4a7ac81-032b-4341-9dfb-dc83634e5ae5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1420, line 1423) (in query: SELECT toModifiedJulianDay(NULL, NULL, NULL);) 2025.11.13 09:13:25.228019 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:25.342351 [ 18771 ] {8b1ec8f0-5ebb-404b-872a-cdac0cf1bb2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1421, line 1424) (in query: SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL);) 2025.11.13 09:13:25.356089 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:25.685466 [ 18771 ] {fa2bcffa-03af-4552-a2d9-919bc0594da0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1425, line 1428) (in query: SELECT toNullable(NULL, NULL, NULL);) 2025.11.13 09:13:25.693652 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:25.801768 [ 19619 ] {7fffebf7-a351-4b16-8326-99a8a2ab45bf} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 9, line 10) (in query: SELECT snowflakeIDToDateTime(123::UInt64, 'invalid_epoch');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:25.806553 [ 19619 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:26.097846 [ 16390 ] {3595bc0e-02f0-48e5-92a5-8d3d42d86237} executeQuery: Code: 43. DB::Exception: Illegal type Int8 of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny('hello some world', -1, ['^hello.*world$']). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53120) (comment: 00929_multi_match_edit_distance.sql) (query 16, line 23) (in query: select multiFuzzyMatchAny('hello some world', -1, ['^hello.*world$']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionsMultiStringFuzzySearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000016c5a5ac 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:13:26.102391 [ 16390 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Int8 of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny('hello some world', -1, ['^hello.*world$']). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionsMultiStringFuzzySearch>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000016c5a5ac 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:13:26.333991 [ 18771 ] {98639380-54f1-45fe-bd16-f79e8943d0b3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=843). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1431, line 1434) (in query: SELECT toRelativeQuarterNum(NULL, NULL, NULL);) 2025.11.13 09:13:26.348434 [ 18771 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=843). (CANNOT_SCHEDULE_TASK) 2025.11.13 09:13:27.478220 [ 19619 ] {d2714d95-2fcf-4754-a96b-73582cc17cdd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 10, line 11) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, 'invalid_epoch');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:27.483287 [ 19619 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:27.499851 [ 16390 ] {95f56c09-0f74-4ac4-9888-97f5fe3e15bb} executeQuery: Code: 44. DB::Exception: Illegal column Const(UInt64). The number is not const or does not fit in UInt32: In scope SELECT multiFuzzyMatchAny('hello some world', 10000000000, ['^hello.*world$']). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53120) (comment: 00929_multi_match_edit_distance.sql) (query 17, line 24) (in query: select multiFuzzyMatchAny('hello some world', 10000000000, ['^hello.*world$']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c582a3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:13:27.503422 [ 16390 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Const(UInt64). The number is not const or does not fit in UInt32: In scope SELECT multiFuzzyMatchAny('hello some world', 10000000000, ['^hello.*world$']). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c582a3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:13:27.663535 [ 19619 ] {0d3d3d62-30bd-4f52-aa96-5e25bf063f94} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 11, line 12) (in query: SELECT snowflakeIDToDateTime(123::UInt64, materialize(42));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:27.667713 [ 19619 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:27.723921 [ 19619 ] {d442072f-bb3d-4cac-8ed0-e460b467a25d} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 12, line 13) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, materialize(42));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:27.728455 [ 19619 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:27.782349 [ 19619 ] {4000309a-bd19-4947-87b6-45ad409a3ef5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 13, line 14) (in query: SELECT snowflakeIDToDateTime(123::UInt64, 42, 42);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:27.790680 [ 19619 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:27.869347 [ 19619 ] {3094ffc3-e600-42e8-a3b7-b1c68f8c5aa3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime64'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 14, line 15) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, 42, 42);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:27.873803 [ 19619 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime64'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:27.907396 [ 19619 ] {77aa60a6-c3b8-4e80-b17f-8adb581c4151} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 15, line 16) (in query: SELECT snowflakeIDToDateTime(123::UInt64, 42, 'UTC', 'too_many_args');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:13:28.069508 [ 19619 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:13:28.098409 [ 19619 ] {c96ca92b-34c4-43da-8e82-5b70bfa868d4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53094) (comment: 01942_snowflakeIDToDateTime.sql) (query 16, line 17) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, 42, 'UTC', 'too_many_args');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:13:28.102454 [ 19619 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:13:28.413005 [ 18771 ] {d15cbea8-54e2-44d0-9e3a-2fb56ab07584} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1454, line 1457) (in query: SELECT toStringCutToZero(NULL, NULL, NULL);) 2025.11.13 09:13:28.423366 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:28.515743 [ 18771 ] {ac52f431-e39c-4b54-aee3-18fde5f46ba7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1456, line 1459) (in query: SELECT toTimeZone(NULL, NULL, NULL);) 2025.11.13 09:13:28.524616 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:28.542725 [ 18771 ] {c7a95558-9543-4ff7-bd13-eda9aa6521f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1457, line 1460) (in query: SELECT toTimezone(NULL, NULL, NULL);) 2025.11.13 09:13:28.548718 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:28.568017 [ 18771 ] {34ff940e-af9a-43a2-8707-cf9cc3fc39da} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1458, line 1461) (in query: SELECT toTypeName(NULL, NULL, NULL);) 2025.11.13 09:13:28.570109 [ 16231 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:28.570768 [ 16231 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:28.575121 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:28.673677 [ 18771 ] {7270a837-5d31-4500-9b36-c862a4de1e48} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1460, line 1463) (in query: SELECT toUInt128OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:28.679692 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:28.861674 [ 18771 ] {db93d53b-8649-4d54-912e-50e0c895e0fd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1464, line 1467) (in query: SELECT toUInt16OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:28.871938 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:29.048082 [ 18771 ] {20952913-6276-475e-b9e4-def4df93921e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1468, line 1471) (in query: SELECT toUInt256OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:29.056982 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:29.263912 [ 18771 ] {c98ef9d6-2393-4cc0-b597-942f1148b779} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1472, line 1475) (in query: SELECT toUInt32OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:29.269475 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:29.317353 [ 16047 ] {} TCPHandler: TCPHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:29.317840 [ 16047 ] {} ServerErrorHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff79cc 6. ./build_docker/./src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x000000003aebfe53 7. ./build_docker/./src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x000000003aea10ff 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:29.385561 [ 2997 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:29.457126 [ 2997 ] {} DynamicQueryHandler: Code: 194. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you use ClickHouse Cloud, the password can be reset at https://clickhouse.cloud/ on the settings page for the corresponding service. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (REQUIRED_PASSWORD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:29.489123 [ 16109 ] {cc4d93eb-2141-4765-861b-b818375977de} executeQuery: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48824) (comment: 02946_parallel_replicas_force_primary_key.sql) (query 16, line 38) (in query: -- parallel replicas, primary key is NOT used SELECT k, count() FROM t1 GROUP BY k ORDER BY k SETTINGS force_primary_key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000385ebcaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1815: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c2ab9cb 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1572: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c2aa6a2 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1567: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c2a9e37 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2055: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c2c0e58 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2163: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c795c 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:13:29.494280 [ 16109 ] {} TCPHandler: Code: 277. DB::Exception: Primary key (k) is not used and setting 'force_primary_key' is set. (INDEX_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type>, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000385ebcaa 4. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1815: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c2ab9cb 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1572: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c2aa6a2 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1567: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c2a9e37 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2055: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c2c0e58 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2163: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c795c 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:13:29.510264 [ 18771 ] {a90bf825-288b-43d2-972c-ad35cd358215} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1476, line 1479) (in query: SELECT toUInt64OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:29.517283 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:29.928263 [ 18771 ] {30b67cb3-5d72-4d8a-aa88-d35979a3d64d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1480, line 1483) (in query: SELECT toUInt8OrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:29.938021 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:30.048508 [ 18771 ] {cabd988d-201d-48c7-a7b6-8d0cdc2c0acd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1483, line 1486) (in query: SELECT toUTCTimestamp(NULL, NULL, NULL);) 2025.11.13 09:13:30.057698 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:30.151664 [ 18771 ] {2f6c92d4-d239-42ae-93e5-78f5b2b3004f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1485, line 1488) (in query: SELECT toUUIDOrDefault(NULL, NULL, NULL);) 2025.11.13 09:13:30.156921 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:30.376223 [ 18771 ] {2c41c531-cd0b-4e47-b0c1-df3c4591d64c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1489, line 1492) (in query: SELECT toUnixTimestamp64Micro(NULL, NULL, NULL);) 2025.11.13 09:13:30.386278 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:30.407065 [ 18771 ] {975085b2-365a-4f10-8ee9-58bbfb5363f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1490, line 1493) (in query: SELECT toUnixTimestamp64Milli(NULL, NULL, NULL);) 2025.11.13 09:13:30.416055 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:30.483260 [ 18771 ] {eef2f7fd-ad3e-4bc5-b758-6a2090b1d7c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1491, line 1494) (in query: SELECT toUnixTimestamp64Nano(NULL, NULL, NULL);) 2025.11.13 09:13:30.492299 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:30.509880 [ 18771 ] {5b1901a2-1c1a-44d5-8982-7531ceb026c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1492, line 1495) (in query: SELECT toUnixTimestamp64Second(NULL, NULL, NULL);) 2025.11.13 09:13:30.518159 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:30.543256 [ 18771 ] {192acf26-bf36-464f-8438-7ade81b6aff9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1493, line 1496) (in query: SELECT toValidUTF8(NULL, NULL, NULL);) 2025.11.13 09:13:30.550424 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:30.923848 [ 16231 ] {a4dfb0d9-5bd1-4233-8ed6-984297ed4375} executeQuery: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49062) (comment: 02696_ignore_inacc_tables_mat_view_atttach.sql) (query 8, line 16) (in query: CREATE TABLE test_table (`n` Int32, `s` String) ENGINE = MergeTree PARTITION BY n ORDER BY n SETTINGS index_granularity = 44252, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 13, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 512915888, compact_parts_max_granules_to_buffer = 80, compact_parts_merge_max_bytes_to_prefetch_part = 26546243, merge_max_block_size = 17198, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 30308938, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 47, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 80000, primary_key_compress_block_size = 11065, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:30.928341 [ 16231 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:31.341368 [ 18389 ] {5b3bc3bd-6e8a-43ba-a6f0-619dc460ebc2} executeQuery: Code: 452. DB::Exception: Setting `min_rows_to_keep` cannot be higher than the `max_rows_to_keep`. `min_rows_to_keep`: 100, `max_rows_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03009_storage_memory_circ_buffer_usage.sql) (in query: /* ddl_entry=query-0000000094 */ CREATE TABLE test_11.faulty_memory UUID 'cb699c9b-e8ed-4a90-baab-64d6fa8da226' (`i` UInt32) ENGINE = Memory SETTINGS min_rows_to_keep = 100), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. ./build_docker/./src/Storages/MemorySettings.cpp:102: DB::MemorySettings::sanityCheck() const @ 0x00000000383b2b70 5. ./build_docker/./src/Storages/StorageMemory.cpp:641: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003877fd09 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:13:31.349732 [ 18389 ] {5b3bc3bd-6e8a-43ba-a6f0-619dc460ebc2} executeQuery: Code: 452. DB::Exception: Setting `min_rows_to_keep` cannot be higher than the `max_rows_to_keep`. `min_rows_to_keep`: 100, `max_rows_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48838) (comment: 03009_storage_memory_circ_buffer_usage.sql) (query 36, line 60) (in query: CREATE TABLE faulty_memory (i UInt32) ENGINE = Memory SETTINGS min_rows_to_keep = 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. ./build_docker/./src/Storages/MemorySettings.cpp:102: DB::MemorySettings::sanityCheck() const @ 0x00000000383b2b70 5. ./build_docker/./src/Storages/StorageMemory.cpp:641: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003877fd09 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:13:31.354037 [ 18389 ] {} TCPHandler: Code: 452. DB::Exception: Setting `min_rows_to_keep` cannot be higher than the `max_rows_to_keep`. `min_rows_to_keep`: 100, `max_rows_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. ./build_docker/./src/Storages/MemorySettings.cpp:102: DB::MemorySettings::sanityCheck() const @ 0x00000000383b2b70 5. ./build_docker/./src/Storages/StorageMemory.cpp:641: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003877fd09 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:13:31.388634 [ 18771 ] {a7a8a406-683a-4194-892f-ef55a6bee09b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1501, line 1504) (in query: SELECT to_utc_timestamp(NULL, NULL, NULL);) 2025.11.13 09:13:31.398751 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:31.502275 [ 18771 ] {5390b5a2-0b8a-4aaf-b0fa-0e513ed7d599} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1502, line 1505) (in query: SELECT today(NULL, NULL, NULL);) 2025.11.13 09:13:31.511203 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:31.530485 [ 18771 ] {126aa521-5525-4c24-93ab-b993f96f4f7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1503, line 1506) (in query: SELECT tokens(NULL, NULL, NULL);) 2025.11.13 09:13:31.539662 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:31.740472 [ 18771 ] {5b3096c9-9d75-4257-b6fc-86b2f3856a65} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1506, line 1509) (in query: SELECT topLevelDomain(NULL, NULL, NULL);) 2025.11.13 09:13:31.749082 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:31.767143 [ 18771 ] {3fc57699-cc4d-41d4-aee8-0798bfdf32c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1507, line 1510) (in query: SELECT topLevelDomainRFC(NULL, NULL, NULL);) 2025.11.13 09:13:31.774286 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:31.794269 [ 18771 ] {6ce61ae9-3321-4000-a575-d08b96efc364} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1508, line 1511) (in query: SELECT transactionID(NULL, NULL, NULL);) 2025.11.13 09:13:31.800711 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:31.823168 [ 18771 ] {922ba95e-1bfb-4400-9e79-7901a7c974bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1509, line 1512) (in query: SELECT transactionLatestSnapshot(NULL, NULL, NULL);) 2025.11.13 09:13:31.828971 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:31.865724 [ 18771 ] {b737d7aa-f3fb-4c68-acee-6152603a5f74} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1510, line 1513) (in query: SELECT transactionOldestSnapshot(NULL, NULL, NULL);) 2025.11.13 09:13:31.873340 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:31.891743 [ 18771 ] {5534461b-ee8a-4cf5-b50c-a15dd7ae6491} executeQuery: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1511, line 1514) (in query: SELECT transform(NULL, NULL, NULL);) 2025.11.13 09:13:31.898024 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: Second argument of function transform, must be array of source values to transform from: In scope SELECT transform(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:32.378481 [ 18771 ] {36e32782-06b3-4dcc-bf3e-fdc672ac473a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1519, line 1523) (in query: SELECT tryBase58Decode(NULL, NULL, NULL);) 2025.11.13 09:13:32.386884 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:32.404839 [ 18771 ] {ebcb51ba-3090-4d7b-bda1-557e5a2465c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1520, line 1524) (in query: SELECT tryBase64Decode(NULL, NULL, NULL);) 2025.11.13 09:13:32.412999 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:32.430058 [ 18771 ] {6a2dd4e5-7a4c-4cc3-958a-a3421584dbfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1521, line 1525) (in query: SELECT tryBase64URLDecode(NULL, NULL, NULL);) 2025.11.13 09:13:32.437482 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:32.504486 [ 18771 ] {c2ea1a49-fcdd-4a46-a32c-38177e7f3ce7} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1523, line 1527) (in query: SELECT tryIdnaEncode(NULL, NULL, NULL);) 2025.11.13 09:13:32.513100 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:32.607484 [ 18771 ] {24734d47-6ca1-43b3-af00-b4a013aa2aa4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1524, line 1528) (in query: SELECT tryPunycodeDecode(NULL, NULL, NULL);) 2025.11.13 09:13:32.614047 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.044121 [ 18771 ] {2829a995-9169-4804-99f7-eb457f10b8da} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1530, line 1534) (in query: SELECT tupleDivide(NULL, NULL, NULL);) 2025.11.13 09:13:33.050056 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.075845 [ 18771 ] {9807f5d5-e1da-427a-be34-5a5e61646d48} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1531, line 1535) (in query: SELECT tupleDivideByNumber(NULL, NULL, NULL);) 2025.11.13 09:13:33.085838 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.109978 [ 18771 ] {6a71f1fa-3d50-464c-9de6-58b0cb0f8cc0} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1532, line 1536) (in query: SELECT tupleElement(NULL, NULL, NULL);) 2025.11.13 09:13:33.120474 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Nullable(Nothing): In scope SELECT tupleElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:33.139088 [ 18771 ] {1f700915-8a3a-421e-b53c-401d1e88e7de} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1533, line 1537) (in query: SELECT tupleHammingDistance(NULL, NULL, NULL);) 2025.11.13 09:13:33.142876 [ 18392 ] {b8d83a64-8bdf-477e-9da3-6acc49e9b1ff} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT if((rand() % 2) = 0, number, toString(number)) FROM numbers(5). (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49032) (comment: 00835_if_generic_case.sql) (query 15, line 20) (in query: SELECT rand() % 2 = 0 ? number : toString(number) FROM numbers(5);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000306c646a 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:33.147071 [ 18392 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT if((rand() % 2) = 0, number, toString(number)) FROM numbers(5). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000306c646a 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:13:33.147523 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.165520 [ 18771 ] {d693bb6d-0156-45ec-a44d-913607be3915} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1534, line 1538) (in query: SELECT tupleIntDiv(NULL, NULL, NULL);) 2025.11.13 09:13:33.173187 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.192419 [ 18771 ] {cdb47de6-375e-436f-9133-7daec55bc23f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1535, line 1539) (in query: SELECT tupleIntDivByNumber(NULL, NULL, NULL);) 2025.11.13 09:13:33.197910 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.217644 [ 18771 ] {c53dc58b-16f3-439e-b22f-4295ccd28062} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1536, line 1540) (in query: SELECT tupleIntDivOrZero(NULL, NULL, NULL);) 2025.11.13 09:13:33.223766 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.243518 [ 18771 ] {a368ee64-bf79-4500-b118-27203776be80} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1537, line 1541) (in query: SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL);) 2025.11.13 09:13:33.251829 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.272247 [ 18389 ] {41c6ecc0-d492-4342-9a57-bf1bbe45b15e} executeQuery: Code: 452. DB::Exception: Setting `min_bytes_to_keep` cannot be higher than the `max_bytes_to_keep`. `min_bytes_to_keep`: 100, `max_bytes_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03009_storage_memory_circ_buffer_usage.sql) (in query: /* ddl_entry=query-0000000095 */ CREATE TABLE test_11.faulty_memory UUID '582826e0-e27f-4716-9bc4-4fac276ee330' (`i` UInt32) ENGINE = Memory SETTINGS min_bytes_to_keep = 100), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. ./build_docker/./src/Storages/MemorySettings.cpp:94: DB::MemorySettings::sanityCheck() const @ 0x00000000383b2a22 5. ./build_docker/./src/Storages/StorageMemory.cpp:641: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003877fd09 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:13:33.273068 [ 18771 ] {73434213-eca4-4386-8c79-1bccea1da1fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1538, line 1542) (in query: SELECT tupleMinus(NULL, NULL, NULL);) 2025.11.13 09:13:33.280018 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.280519 [ 18389 ] {41c6ecc0-d492-4342-9a57-bf1bbe45b15e} executeQuery: Code: 452. DB::Exception: Setting `min_bytes_to_keep` cannot be higher than the `max_bytes_to_keep`. `min_bytes_to_keep`: 100, `max_bytes_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48838) (comment: 03009_storage_memory_circ_buffer_usage.sql) (query 37, line 61) (in query: CREATE TABLE faulty_memory (i UInt32) ENGINE = Memory SETTINGS min_bytes_to_keep = 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. ./build_docker/./src/Storages/MemorySettings.cpp:94: DB::MemorySettings::sanityCheck() const @ 0x00000000383b2a22 5. ./build_docker/./src/Storages/StorageMemory.cpp:641: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003877fd09 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:13:33.284520 [ 18389 ] {} TCPHandler: Code: 452. DB::Exception: Setting `min_bytes_to_keep` cannot be higher than the `max_bytes_to_keep`. `min_bytes_to_keep`: 100, `max_bytes_to_keep`: 0. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. ./build_docker/./src/Storages/MemorySettings.cpp:94: DB::MemorySettings::sanityCheck() const @ 0x00000000383b2a22 5. ./build_docker/./src/Storages/StorageMemory.cpp:641: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000003877fd09 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 14. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:13:33.303521 [ 18771 ] {09caeb83-b1c6-4ade-9ce2-8a177e4d8f6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1539, line 1543) (in query: SELECT tupleModulo(NULL, NULL, NULL);) 2025.11.13 09:13:33.312267 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.355374 [ 18771 ] {15d46af1-5117-4211-a76b-b340f9b39b14} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1540, line 1544) (in query: SELECT tupleModuloByNumber(NULL, NULL, NULL);) 2025.11.13 09:13:33.363750 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.382307 [ 18771 ] {2bf4a6b5-1ae1-4007-8f10-662a0d7f0fdd} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1541, line 1545) (in query: SELECT tupleMultiply(NULL, NULL, NULL);) 2025.11.13 09:13:33.387730 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.441621 [ 18771 ] {9ed2033b-d708-4625-a4cc-11eff7e5878b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1542, line 1546) (in query: SELECT tupleMultiplyByNumber(NULL, NULL, NULL);) 2025.11.13 09:13:33.449301 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.467940 [ 18771 ] {848bfc3a-ae1a-4eda-932b-097464602df7} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1543, line 1547) (in query: SELECT tupleNames(NULL, NULL, NULL);) 2025.11.13 09:13:33.476919 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.495340 [ 18771 ] {e1dfe9b6-d8b4-4843-84a3-78f6e0c96243} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1544, line 1548) (in query: SELECT tupleNegate(NULL, NULL, NULL);) 2025.11.13 09:13:33.579973 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.599077 [ 18771 ] {7b136474-6c66-48e1-8752-7f284af54720} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1545, line 1549) (in query: SELECT tuplePlus(NULL, NULL, NULL);) 2025.11.13 09:13:33.604622 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.629695 [ 18771 ] {5df64726-d5ce-44bc-9278-7df6a6c600ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1546, line 1550) (in query: SELECT tupleToNameValuePairs(NULL, NULL, NULL);) 2025.11.13 09:13:33.635391 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.657245 [ 18771 ] {73fa7456-4240-4d5d-aa42-452d71235997} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1547, line 1551) (in query: SELECT ucase(NULL, NULL, NULL);) 2025.11.13 09:13:33.662940 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.775261 [ 18771 ] {a9bd75e1-e0ad-4b15-9bf7-6529c9da06fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1548, line 1552) (in query: SELECT unbin(NULL, NULL, NULL);) 2025.11.13 09:13:33.829185 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:33.852499 [ 18771 ] {4706659b-0f48-4ece-9f0a-048c6cff5988} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1549, line 1553) (in query: SELECT unhex(NULL, NULL, NULL);) 2025.11.13 09:13:33.862364 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:34.564772 [ 18771 ] {c92a3f48-f9d4-4130-a0d8-db9e22271922} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1556, line 1560) (in query: SELECT uniqThetaIntersect(NULL, NULL, NULL);) 2025.11.13 09:13:34.571206 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:34.592054 [ 18771 ] {c7214f9b-b529-4404-a362-193eb1a92d7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1557, line 1561) (in query: SELECT uniqThetaNot(NULL, NULL, NULL);) 2025.11.13 09:13:34.598125 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:34.616075 [ 18771 ] {8d26d075-94d2-4259-87e6-69b184c4eac3} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1558, line 1562) (in query: SELECT uniqThetaUnion(NULL, NULL, NULL);) 2025.11.13 09:13:34.622000 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:34.903586 [ 18771 ] {88f128e7-a85b-4bbb-8590-782fba493ce4} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1560, line 1564) (in query: SELECT upper(NULL, NULL, NULL);) 2025.11.13 09:13:34.911812 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:34.929958 [ 18771 ] {494bf7f8-57b5-41dc-8ada-26ff22d4c279} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1561, line 1565) (in query: SELECT upperUTF8(NULL, NULL, NULL);) 2025.11.13 09:13:34.938309 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:34.956545 [ 18771 ] {c2c10edf-1fa1-4ca8-a326-1487f7b85575} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1562, line 1566) (in query: SELECT uptime(NULL, NULL, NULL);) 2025.11.13 09:13:34.964701 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:34.984902 [ 18771 ] {0f6bd667-e1d7-45a2-a90b-0b6ff416bf96} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1563, line 1567) (in query: SELECT user(NULL, NULL, NULL);) 2025.11.13 09:13:34.993283 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:35.150755 [ 18392 ] {0783665e-b66f-4bd4-9bf2-6a812b14e81a} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(groupArray(9223372036854775807), UInt32) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: groupArray instead of groupArray. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53228) (comment: 01632_group_array_msan.sql) (query 1, line 1) (in query: SELECT groupArrayMerge(1048577)(y * 1048576) FROM (SELECT groupArrayState(9223372036854775807)(x) AS y FROM (SELECT 1048576 AS x)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002666e6d9 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d163f84 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:13:35.155474 [ 18392 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(groupArray(9223372036854775807), UInt32) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: groupArray instead of groupArray. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002666e6d9 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d163f84 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:13:35.355685 [ 16223 ] {50e94ca0-4f5a-4ed9-8c06-284d7e0ae89d} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53278) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_r1 DELETE WHERE x = 1 SETTINGS mutations_sync = 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:35.361734 [ 16223 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:35.749042 [ 18771 ] {c18bab10-45a4-42c0-aece-1de6dd61f283} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1569, line 1573) (in query: SELECT variantElement(NULL, NULL, NULL);) 2025.11.13 09:13:35.759195 [ 18771 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Nullable(Nothing): In scope SELECT variantElement(NULL, NULL, NULL). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:13:35.778394 [ 18771 ] {4658c865-0cc2-4049-bc01-1e1bb6cdf262} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1570, line 1574) (in query: SELECT variantType(NULL, NULL, NULL);) 2025.11.13 09:13:35.784165 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:35.804485 [ 18771 ] {f1c940e5-dd35-4597-9a62-31682589acb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1571, line 1575) (in query: SELECT vectorDifference(NULL, NULL, NULL);) 2025.11.13 09:13:35.812784 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:35.841529 [ 18771 ] {0cdf81bf-0a88-4139-9408-2ac32b6a2111} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1572, line 1576) (in query: SELECT vectorSum(NULL, NULL, NULL);) 2025.11.13 09:13:35.848822 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:35.869468 [ 18771 ] {30b423ee-b62b-4bb6-b9eb-332532c11007} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1573, line 1577) (in query: SELECT version(NULL, NULL, NULL);) 2025.11.13 09:13:35.959905 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:35.987621 [ 18392 ] {4354a84b-3d6f-4e11-bf31-7bbecc33cfa9} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(quantileResample(0.1, 1, 2, 42), UInt64, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: quantileResample instead of quantileResample. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53228) (comment: 01632_group_array_msan.sql) (query 4, line 4) (in query: SELECT quantileResampleMerge(0.5, 257, 65536, 1)(tuple(*).1) FROM (SELECT quantileResampleState(0.10, 1, 2, 42)(number, number) FROM numbers(100));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002666e6d9 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d163f84 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:13:35.992982 [ 18392 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(quantileResample(0.1, 1, 2, 42), UInt64, UInt64) of argument for aggregate function with Merge suffix. because it corresponds to different aggregate function: quantileResample instead of quantileResample. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMerge.cpp:67: DB::(anonymous namespace)::AggregateFunctionCombinatorMerge::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002666e6d9 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x000000002d163f84 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:13:35.996604 [ 18771 ] {7ef9ebbe-e99c-4a0c-a29b-39b5c9863a35} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1574, line 1578) (in query: SELECT visibleWidth(NULL, NULL, NULL);) 2025.11.13 09:13:36.002772 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:36.024615 [ 18771 ] {3d5ed42a-e4da-4d04-97fb-2b286b05d331} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1575, line 1579) (in query: SELECT visitParamExtractBool(NULL, NULL, NULL);) 2025.11.13 09:13:36.030901 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:36.120551 [ 18771 ] {c78f66fa-0d61-41d2-94e5-ead6c2ab6f6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1576, line 1580) (in query: SELECT visitParamExtractFloat(NULL, NULL, NULL);) 2025.11.13 09:13:36.126195 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:36.140130 [ 19172 ] {0829870b-21c8-426f-a653-1a9d03df5776} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53330) (comment: 02553_type_json_attach_partition.sql) (query 1, line 1) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:13:36.145886 [ 19172 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:13:36.147816 [ 18771 ] {c837c0a2-ecb3-4a78-9ea6-46dd646dba35} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1577, line 1581) (in query: SELECT visitParamExtractInt(NULL, NULL, NULL);) 2025.11.13 09:13:36.156859 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:36.176068 [ 18771 ] {260c3383-7054-4641-9c1c-3ce763e4cc03} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1578, line 1582) (in query: SELECT visitParamExtractRaw(NULL, NULL, NULL);) 2025.11.13 09:13:36.183832 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:36.202032 [ 18771 ] {f2c69072-da1b-430d-ad0c-7fcb9dadb6ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1579, line 1583) (in query: SELECT visitParamExtractString(NULL, NULL, NULL);) 2025.11.13 09:13:36.208272 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:36.228543 [ 18771 ] {b7ef3f6f-b2fd-4713-a8d3-6bc89ea0b600} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1580, line 1584) (in query: SELECT visitParamExtractUInt(NULL, NULL, NULL);) 2025.11.13 09:13:36.238334 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:36.259810 [ 18771 ] {00667bfc-e395-4066-90bc-eebe66089e33} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1581, line 1585) (in query: SELECT visitParamHas(NULL, NULL, NULL);) 2025.11.13 09:13:36.266985 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:36.402888 [ 18771 ] {68c18f60-d6ad-4e53-9afb-72d8dc7d5787} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1584, line 1588) (in query: SELECT widthBucket(NULL, NULL, NULL);) 2025.11.13 09:13:36.409385 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:36.430931 [ 18771 ] {7ba8b666-019c-437b-b103-e4b9f3fb24e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1585, line 1589) (in query: SELECT width_bucket(NULL, NULL, NULL);) 2025.11.13 09:13:36.528557 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:36.777668 [ 18771 ] {598cff9f-24e8-46a7-bf2e-0b83ef87e8d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1588, line 1592) (in query: SELECT wkt(NULL, NULL, NULL);) 2025.11.13 09:13:36.783940 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:37.457626 [ 17752 ] {a1798bed-e313-4d3b-9ee5-36655471e455} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53354) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO mutations_r1(d, x, s) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000032adeec7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:13:37.469962 [ 17752 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000032adeec7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:13:38.090216 [ 16390 ] {72e81b3d-2919-4050-8a11-e221910cbe16} executeQuery: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': while executing 'FUNCTION multiFuzzyMatchAny(materialize('abc'_String) :: 4, 3_UInt8 :: 2, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('abc'_String), 3_UInt8, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53120) (comment: 00929_multi_match_edit_distance.sql) (query 30, line 40) (in query: select multiFuzzyMatchAny(materialize('abc'), 3, materialize(['a1c'])) from system.numbers limit 3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x0000000016c5f63f 5. DB::MultiRegexps::Regexps std::__function::__policy_invoker::__call_impl[abi:ne190107] DB::MultiRegexps::getOrSet(std::vector>, std::allocator>>> const&, std::optional)::'lambda'(), DB::MultiRegexps::Regexps ()>>(std::__function::__policy_storage const*) @ 0x0000000016c5dfa2 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x0000000016c4965b 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c56b8f 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:13:38.097349 [ 16390 ] {} TCPHandler: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': while executing 'FUNCTION multiFuzzyMatchAny(materialize('abc'_String) :: 4, 3_UInt8 :: 2, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('abc'_String), 3_UInt8, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x0000000016c5f63f 5. DB::MultiRegexps::Regexps std::__function::__policy_invoker::__call_impl[abi:ne190107] DB::MultiRegexps::getOrSet(std::vector>, std::allocator>>> const&, std::optional)::'lambda'(), DB::MultiRegexps::Regexps ()>>(std::__function::__policy_storage const*) @ 0x0000000016c5dfa2 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x0000000016c4965b 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c56b8f 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:13:38.156494 [ 18771 ] {1fa6602b-a342-4a31-9fc1-fdebeaf2bf5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1606, line 1610) (in query: SELECT yandexConsistentHash(NULL, NULL, NULL);) 2025.11.13 09:13:38.162111 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:38.171466 [ 16390 ] {377da2ee-270b-44d1-8284-bc0e37bea138} executeQuery: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': while executing 'FUNCTION multiFuzzyMatchAny(materialize('abc'_String) :: 4, 4_UInt8 :: 2, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('abc'_String), 4_UInt8, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53120) (comment: 00929_multi_match_edit_distance.sql) (query 31, line 41) (in query: select multiFuzzyMatchAny(materialize('abc'), 4, materialize(['a1c'])) from system.numbers limit 3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x0000000016c5f63f 5. DB::MultiRegexps::Regexps std::__function::__policy_invoker::__call_impl[abi:ne190107] DB::MultiRegexps::getOrSet(std::vector>, std::allocator>>> const&, std::optional)::'lambda'(), DB::MultiRegexps::Regexps ()>>(std::__function::__policy_storage const*) @ 0x0000000016c5dfa2 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x0000000016c4965b 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c56b8f 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:13:38.177990 [ 16390 ] {} TCPHandler: Code: 36. DB::Exception: Pattern 'a1c' failed with error 'Approximate matching patterns that reduce to vacuous patterns are disallowed.': while executing 'FUNCTION multiFuzzyMatchAny(materialize('abc'_String) :: 4, 4_UInt8 :: 2, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('abc'_String), 4_UInt8, materialize(_CAST(['a1c']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. DB::MultiRegexps::Regexps DB::MultiRegexps::constructRegexps(std::vector> const&, std::optional) @ 0x0000000016c5f63f 5. DB::MultiRegexps::Regexps std::__function::__policy_invoker::__call_impl[abi:ne190107] DB::MultiRegexps::getOrSet(std::vector>, std::allocator>>> const&, std::optional)::'lambda'(), DB::MultiRegexps::Regexps ()>>(std::__function::__policy_storage const*) @ 0x0000000016c5dfa2 6. DB::MultiRegexps::DeferredConstructedRegexps::get() @ 0x0000000016c4965b 7. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c56b8f 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 13. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 14. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:13:38.285997 [ 18771 ] {d9c5a1e7-c395-4cb3-9322-2fa8572e9386} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1608, line 1612) (in query: SELECT yesterday(NULL, NULL, NULL);) 2025.11.13 09:13:38.292198 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:38.316135 [ 18771 ] {051943c1-1dee-4e28-9e53-ef2b7650722a} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57294) (comment: 00534_functions_bad_arguments11.sh) (query 1609, line 1613) (in query: SELECT zookeeperSessionUptime(NULL, NULL, NULL);) 2025.11.13 09:13:38.322090 [ 18771 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime(NULL, NULL, NULL). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:13:38.399457 [ 17752 ] {0566eeb5-9140-4cea-a275-799f0ea876f4} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53466) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO mutations_r1(d, x, s) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000032adeec7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:13:38.407260 [ 17752 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000032adeec7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:13:38.879955 [ 16231 ] {de8f3807-3d33-4808-a54e-98243a63afc3} executeQuery: Code: 128. DB::Exception: Too many matches per row (> 1000) in the result of function extractAllGroupsHorizontal: while executing 'FUNCTION extractAllGroupsHorizontal(repeat('abcdefghijklmnopqrstuvwxyz'_String, multiply(__table1.number, 100_UInt8)) : 2, '(\\w)'_String :: 3) -> extractAllGroupsHorizontal(repeat('abcdefghijklmnopqrstuvwxyz'_String, multiply(__table1.number, 100_UInt8)), '(\\w)'_String) Array(Array(String)) : 0'. (TOO_LARGE_ARRAY_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53234) (comment: 01661_extract_all_groups_throw_fast.sql) (query 1, line 1) (in query: SELECT repeat('abcdefghijklmnopqrstuvwxyz', number * 100) AS haystack, extractAllGroupsHorizontal(haystack, '(\\w)') AS matches FROM numbers(1023);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000ecb662d 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ecb4542 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:13:38.887857 [ 16231 ] {} TCPHandler: Code: 128. DB::Exception: Too many matches per row (> 1000) in the result of function extractAllGroupsHorizontal: while executing 'FUNCTION extractAllGroupsHorizontal(repeat('abcdefghijklmnopqrstuvwxyz'_String, multiply(__table1.number, 100_UInt8)) : 2, '(\\w)'_String :: 3) -> extractAllGroupsHorizontal(repeat('abcdefghijklmnopqrstuvwxyz'_String, multiply(__table1.number, 100_UInt8)), '(\\w)'_String) Array(Array(String)) : 0'. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000ecb662d 4. DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ecb4542 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:13:38.963782 [ 16390 ] {a57f4ae7-f375-4601-9d73-ca5448bc477b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=842). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53120) (comment: 00929_multi_match_edit_distance.sql) (query 39, line 51) (in query: select multiFuzzyMatchAny(materialize('hello some world'), 10, materialize(['^hello.*world$']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:38.970177 [ 16390 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=842). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:39.462184 [ 17388 ] {186dada6-af8a-4693-8bd3-1e3226ead14b} executeQuery: Code: 48. DB::Exception: Can't execute any of specified join algorithms for this strictness/kind and right storage type: While processing WITH x AS (SELECT number FROM numbers(10)), cross_sales AS (SELECT 1 AS xx FROM x, x AS d1, x AS d2, x AS d3, x AS d4, x AS d5, x AS d6, x AS d7, x AS d8, x AS d9 WHERE x.number = d9.number) SELECT xx FROM cross_sales WHERE xx = 2000. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53452) (comment: 02337_join_analyze_stuck.sql) (query 1, line 3) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/21557 EXPLAIN SYNTAX WITH x AS ( SELECT number FROM numbers(10) ), cross_sales AS ( SELECT 1 AS xx FROM x, x AS d1, x AS d2, x AS d3, x AS d4, x AS d5, x AS d6, x AS d7, x AS d8, x AS d9 WHERE x.number = d9.number ) SELECT xx FROM cross_sales WHERE xx = 2000 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1077: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031bd236c 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031bc9e1b 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031bf83ab 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1178: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032b559da 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032b345ca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b1f0d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b10b98 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032d8bea2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d84d52 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d819d0 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000032d8e307 15. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000033886b5a 16. ./build_docker/./src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x0000000032e2efcb 17. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:586: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b14661 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b10b98 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032d8bea2 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d84d52 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d819d0 22. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000032d8e307 23. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000033886b5a 24. ./build_docker/./src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x0000000032e2efcb 25. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:586: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b14661 26. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b10b98 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032d8bea2 28. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d84d52 29. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d819d0 30. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000032d8e307 31. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000033886b5a 2025.11.13 09:13:39.508538 [ 10177 ] {e2dd2e3a-058b-48e9-86f8-bc6b06d4cc4c} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53596) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_r1 DELETE WHERE nonexistent = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:39.512118 [ 17388 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified join algorithms for this strictness/kind and right storage type: While processing WITH x AS (SELECT number FROM numbers(10)), cross_sales AS (SELECT 1 AS xx FROM x, x AS d1, x AS d2, x AS d3, x AS d4, x AS d5, x AS d6, x AS d7, x AS d8, x AS d9 WHERE x.number = d9.number) SELECT xx FROM cross_sales WHERE xx = 2000. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1077: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031bd236c 5. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031bc9e1b 6. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031bf83ab 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1178: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032b559da 8. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032b345ca 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b1f0d5 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b10b98 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032d8bea2 12. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d84d52 13. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d819d0 14. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000032d8e307 15. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000033886b5a 16. ./build_docker/./src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x0000000032e2efcb 17. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:586: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b14661 18. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b10b98 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032d8bea2 20. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d84d52 21. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d819d0 22. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000032d8e307 23. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000033886b5a 24. ./build_docker/./src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x0000000032e2efcb 25. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:586: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b14661 26. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b10b98 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x0000000032d8bea2 28. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d84d52 29. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032d819d0 30. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000032d8e307 31. ./build_docker/./src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000033886b5a 2025.11.13 09:13:39.514858 [ 10177 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:40.960095 [ 18391 ] {6e8eb306-742f-4350-b4ef-ed49d74176c5} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49242) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_r1 DELETE WHERE d = '11'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:40.972218 [ 18391 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:42.279852 [ 18728 ] {f2a4f8ff-9a31-44e6-8fdb-2cf0e6c51b1d} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49500) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_r1 DELETE WHERE x % 2 = 1 SETTINGS mutations_sync = 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:42.311058 [ 18728 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:43.645272 [ 17226 ] {14e4ed11-fe90-45e7-952c-9b23af22f74c} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49720) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_r1 DELETE WHERE s = 'd' SETTINGS mutations_sync = 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:43.667752 [ 17226 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:45.408451 [ 16207 ] {479269ab-8dac-4df6-af39-5748a7b8ca5d} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49966) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_r1 DELETE WHERE m = 3 SETTINGS mutations_sync = 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:45.417581 [ 16207 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:46.871095 [ 2996 ] {312f3536-676b-48c4-893e-e9fafa43363f} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50244) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO mutations_r1(d, x, s) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000032adeec7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:13:46.887892 [ 2996 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000032adeec7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:13:47.544446 [ 18149 ] {b7b6d4d9-f225-4274-9bca-983475c81c72} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49958) (comment: 01621_summap_check_types.sql) (query 4, line 5) (in query: SELECT [NULL], sumMapWithOverflow(events, [NULL], [[(NULL)]], counts) FROM sum_map_overflow;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002411a605 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:13:47.549221 [ 18149 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:130: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002411a605 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:13:48.133285 [ 6028 ] {1ef957e7-48e7-443a-8905-062665f1896e} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50432) (comment: 01581_deduplicate_by_columns_replicated_long.sql) (query 4, line 13) (in query: CREATE TABLE IF NOT EXISTS replicated_deduplicate_by_columns_r1 (`id` Int32, `val` UInt32, `unique_value` UInt64 MATERIALIZED rowNumberInBlock()) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01581/replicated_deduplicate', 'r1') ORDER BY id SETTINGS index_granularity = 17384, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 460710737, compact_parts_max_bytes_to_buffer = 218861904, compact_parts_max_granules_to_buffer = 146, compact_parts_merge_max_bytes_to_prefetch_part = 8830335, merge_max_block_size = 6028, old_parts_lifetime = 360., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 216670, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 19566976, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 32, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 45348, primary_key_compress_block_size = 50241, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:13:48.154883 [ 6028 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:13:48.508944 [ 3754 ] {} test_6y0c24yc.r2 (0e4768e7-7132-46c0-a644-0f7738eba168): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://d32b9e83770c:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Fclickhouse%2Ftables%2Ftest_6y0c24yc%2Fr%2Freplicas%2Fr1&part=all_0_0_0&client_protocol_version=8&compress=false. HTTP status code: 500 'Internal Server Error', body length: 133 bytes, body: 'Code: 236. DB::Exception: Transferring part to replica was cancelled. (ABORTED) (version 25.3.8.10072.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x0000000020232719 4. ./build_docker/./src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x0000000020232097 5. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x00000000267dc64a 6. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x00000000267dcafc 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x00000000267de4b8 8. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000267e5767 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000267d74c2 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x00000000267e1c32 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:254: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x00000000267db7fe 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x00000000267c153f 14. ./src/IO/ReadWriteBufferFromHTTP.h:248: DB::DataPartsExchange::Fetcher::fetchSelectedPart(std::shared_ptr const&, std::shared_ptr, String const&, String const&, String const&, String const&, int, DB::ConnectionTimeouts const&, String const&, String const&, String const&, std::shared_ptr, bool, String const&, std::optional*, bool, std::shared_ptr) @ 0x00000000394fea1f 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5225: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:ne190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000038c9a912 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000389f0f5f 17. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x00000000389c5b90 18. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x000000003898cdd4 19. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3873: bool std::__function::__policy_invoker&)>::__call_impl[abi:ne190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000038c93ab0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003a3346cc 21. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3869: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000038a686eb 22. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3932: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000038c95a19 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000395c0057 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x0000000039840dc2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000398429cc 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985285f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:49.934401 [ 16192 ] {5d3c8691-b170-4a3b-9d30-51a4a716deac} executeQuery: Code: 628. DB::Exception: Can not use OFFSET FETCH clause without ORDER BY. (OFFSET_FETCH_WITHOUT_ORDER_BY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43872) (comment: 02114_offset_fetch_without_order_by.sh) (in query: SELECT number from numbers(10) OFFSET 1 ROWS FETCH FIRST 1 ROWS ONLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:430: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e26bc22 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e2c1164 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e13e10c 9. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e11df50 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 11. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e26db31 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 13. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:74: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235a67 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 15. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 16. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 17. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 18. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 19. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 20. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 22. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 23. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 24. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:13:49.937698 [ 16192 ] {5d3c8691-b170-4a3b-9d30-51a4a716deac} DynamicQueryHandler: Code: 628. DB::Exception: Can not use OFFSET FETCH clause without ORDER BY. (OFFSET_FETCH_WITHOUT_ORDER_BY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:430: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e26bc22 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e2c1164 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e13e10c 9. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e11df50 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 11. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e26db31 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 13. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:74: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235a67 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 15. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 16. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 17. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 18. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 19. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 20. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 22. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 23. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 24. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:50.616189 [ 16323 ] {ca8769e4-7b45-4fe9-9ffd-34a99cac9cd2} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50544) (comment: 01762_deltasumtimestamp_datetime64.sh) (query 1, line 1) (in query: SELECT deltaSumTimestamp(1, now64());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a2e342d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:237: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020a6931f 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:13:50.637370 [ 16323 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a2e342d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:237: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000020a6931f 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:13:50.892989 [ 16363 ] {89efd69c-7e47-433e-8cbf-4f856d103e6b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=850). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50600) (comment: 02243_make_date32.sql) (query 9, line 10) (in query: select makeDate32(-1980, 10, 17);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:50.908308 [ 16363 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=850). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:53.606453 [ 10170 ] {04cc05a7-8cc6-4c1d-9905-41b89a703722} executeQuery: Code: 36. DB::Exception: Aggregate function mannWhitneyUTest require both samples to be non empty. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54256) (comment: 01802_rank_corr_mann_whitney_over_window.sql) (query 4, line 16) (in query: SELECT mannWhitneyUTest(salary, salary) OVER (ORDER BY salary ROWS BETWEEN CURRENT ROW AND UNBOUNDED FOLLOWING) AS func FROM 01802_empsalary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:234: DB::(anonymous namespace)::AggregateFunctionMannWhitney::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x0000000025dc186b 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1069: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06ec0 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:13:53.614214 [ 10170 ] {} TCPHandler: Code: 36. DB::Exception: Aggregate function mannWhitneyUTest require both samples to be non empty. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:234: DB::(anonymous namespace)::AggregateFunctionMannWhitney::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x0000000025dc186b 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1069: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06ec0 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:13:54.088584 [ 6005 ] {2226fe02-345d-47e2-bf12-39bc973cc33d} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54174) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 14, line 17) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21804 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 14. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:13:54.166108 [ 6005 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21804 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 14. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:13:54.228488 [ 10170 ] {2c44719c-e241-4905-bd37-4162e9b4b91a} executeQuery: Code: 36. DB::Exception: All numbers in both samples are identical. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54256) (comment: 01802_rank_corr_mann_whitney_over_window.sql) (query 5, line 18) (in query: SELECT rankCorr(salary, 0.5) OVER (ORDER BY salary ASC ROWS BETWEEN CURRENT ROW AND UNBOUNDED FOLLOWING) AS func FROM 01802_empsalary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/AggregateFunctions/StatCommon.h:51: std::pair>, double> DB::computeRanksAndTieCorrection, DB::AlignedArenaAllocator<8ul>, 8ul>, 0ul, 0ul>>(DB::PODArray, DB::AlignedArenaAllocator<8ul>, 8ul>, 0ul, 0ul> const&) @ 0x0000000025db64b8 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionRankCorrelation.cpp:33: DB::(anonymous namespace)::AggregateFunctionRankCorrelation::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x0000000025dae475 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1069: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06ec0 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:13:54.235689 [ 10170 ] {} TCPHandler: Code: 36. DB::Exception: All numbers in both samples are identical. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/AggregateFunctions/StatCommon.h:51: std::pair>, double> DB::computeRanksAndTieCorrection, DB::AlignedArenaAllocator<8ul>, 8ul>, 0ul, 0ul>>(DB::PODArray, DB::AlignedArenaAllocator<8ul>, 8ul>, 0ul, 0ul> const&) @ 0x0000000025db64b8 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionRankCorrelation.cpp:33: DB::(anonymous namespace)::AggregateFunctionRankCorrelation::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x0000000025dae475 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1069: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06ec0 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:13:54.352204 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_1_106_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1125: DB::MergeTask::VerticalMergeStage::createPipelineForReadingOneColumn(String const&) const @ 0x00000000397c9176 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1149: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cb25d 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 24. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:54.353281 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_1_106_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1125: DB::MergeTask::VerticalMergeStage::createPipelineForReadingOneColumn(String const&) const @ 0x00000000397c9176 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1149: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cb25d 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 24. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:13:54.732146 [ 6078 ] {fbc4eaca-87de-4871-b863-1675f237e2df} executeQuery: Code: 124. DB::Exception: Incorrect size of tuple in set: 1 instead of 0. (INCORRECT_ELEMENT_OF_SET) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54386) (comment: 03210_empty_tuple_lhs_of_in.sql) (query 1, line 1) (in query: SELECT tuple() IN tuple(1) SETTINGS allow_experimental_map_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. ./build_docker/./src/Analyzer/SetUtils.cpp:122: std::vector> DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x0000000031157324 5. ./build_docker/./src/Analyzer/SetUtils.cpp:184: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000031151357 6. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000003117cdf0 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba11 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 9. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003117b8ab 10. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bef988 11. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:13:54.735761 [ 6078 ] {} TCPHandler: Code: 124. DB::Exception: Incorrect size of tuple in set: 1 instead of 0. (INCORRECT_ELEMENT_OF_SET), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. ./build_docker/./src/Analyzer/SetUtils.cpp:122: std::vector> DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, DB::GetSetElementParams) @ 0x0000000031157324 5. ./build_docker/./src/Analyzer/SetUtils.cpp:184: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000031151357 6. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000003117cdf0 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba11 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 9. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003117b8ab 10. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bef988 11. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:13:54.969195 [ 19618 ] {32c7d003-379e-4f47-a3fe-cfd98c484078} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54430) (comment: 00878_join_unexpected_results.sql) (query 9, line 12) (in query: select * from t left outer join s using (a,b) order by t.a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1293: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec912 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:13:54.976068 [ 19618 ] {} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1293: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec912 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:13:55.725947 [ 19243 ] {1b1354f5-d027-4044-a174-f4de06d3bdf7} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_gk82sz44.Mapping (e2e0a92b-8f31-437d-b995-de6000c9c4e5), because some tables depend on it: test_gk82sz44.Sub_distributed. (HAVE_DEPENDENT_OBJECTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54460) (comment: 02916_joinget_dependency.sh) (query 1, line 2) (in query: DROP TABLE Mapping;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x0000000031b2ec4d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1596: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031b11dff 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1578: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031b13396 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6abc5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:13:55.745788 [ 19243 ] {} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_gk82sz44.Mapping (e2e0a92b-8f31-437d-b995-de6000c9c4e5), because some tables depend on it: test_gk82sz44.Sub_distributed. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x0000000031b2ec4d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1596: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031b11dff 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1578: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x0000000031b13396 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:300: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6abc5 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:13:55.816432 [ 10149 ] {a102c27f-4d45-43b5-b9c8-65eec061931f} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54542) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO mutations_cleaner_r1(x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000032adeec7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:13:55.822518 [ 10149 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000032adeec7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:13:56.069719 [ 6005 ] {2d15b6f5-7a73-423a-a7f5-6ecf2320caef} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54174) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 21, line 24) (in query: SELECT t1.*, t2.* from t1 INNER JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21804 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 14. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:13:56.075447 [ 6005 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21804 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 14. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:13:56.797977 [ 19621 ] {ed25b193-ae4b-4a69-a62f-0c85d3d058d1} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54590) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_cleaner_r1 DELETE WHERE x = 1 SETTINGS mutations_sync = 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:56.804333 [ 19621 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:57.610235 [ 6005 ] {097ff36e-89c8-4a16-baec-fd38ee3f5581} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54174) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 28, line 31) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21804 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 14. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:13:57.615092 [ 6005 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21804 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 14. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:13:57.751518 [ 19619 ] {b1f47eae-1ca4-426f-b73d-75fd3fd2a001} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54656) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_cleaner_r1 DELETE WHERE x = 2 SETTINGS mutations_sync = 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:57.764375 [ 19619 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:58.379306 [ 19499 ] {af84685c-25b2-4514-af5c-977b48151ed7} executeQuery: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02428_parameterized_view_param_in_select_section.sql) (in query: /* ddl_entry=query-0000000105 */ CREATE TABLE test_11.t UUID '03432350-c0c5-465b-a1b2-088bfb6f160e' (`z` String, `ts` DateTime) ENGINE = Memory AS SELECT '1', '2020-01-01 00:00:00'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:58.386420 [ 19499 ] {af84685c-25b2-4514-af5c-977b48151ed7} executeQuery: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54670) (comment: 02428_parameterized_view_param_in_select_section.sql) (query 1, line 1) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/56564 create table t(z String, ts DateTime) Engine=Memory as select '1', '2020-01-01 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:58.392302 [ 19499 ] {} TCPHandler: Code: 57. DB::Exception: Table test_11.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:13:58.745757 [ 19499 ] {0971db4b-ddfd-463f-83fb-25acd508054f} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54696) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_cleaner_r1 DELETE WHERE x = 3 SETTINGS mutations_sync = 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:58.760343 [ 19499 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:13:59.441985 [ 6005 ] {38dd4e3a-dedc-4047-85bf-c3240c6897d9} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54174) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 35, line 38) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21804 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 14. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:13:59.446218 [ 6005 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:30: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21804 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 9. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 10. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 14. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:14:00.688387 [ 16390 ] {84117985-63d9-4d7c-a52f-aabda3f7eb74} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=854). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54770) (comment: 02046_low_cardinality_parallel_group_by.sh) (in query: SELECT count() FROM low_card_buffer_test GROUP BY test_text format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:00.704751 [ 16390 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=854). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:00.708825 [ 17388 ] {dd2c058d-5ab8-4ff6-8d7f-7c5d5d005a39} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55322) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE mutations_cleaner_r1 DELETE WHERE x = 4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:00.714921 [ 17388 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:136: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d3bf 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:00.841253 [ 16215 ] {308b8dc5-9997-4c78-b04f-e6bb200cd3a1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=898). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54736) (comment: 02046_low_cardinality_parallel_group_by.sh) (in query: INSERT INTO low_card_buffer_test values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 7. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:00.849268 [ 16215 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=898). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 7. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:01.188693 [ 16215 ] {2d13e96f-59a6-4516-a828-c01542d083a8} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55354) (comment: 01135_default_and_alter_zookeeper.sql) (query 2, line 5) (in query: CREATE TABLE default_table ( id UInt64, enum_column Enum8('undefined' = 0, 'fox' = 1, 'index' = 2) ) ENGINE ReplicatedMergeTree('/clickhouse/{database}/test_01135/default_table', '1') ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:01.194690 [ 16215 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:01.621439 [ 6072 ] {9342a9dc-64eb-43f5-ab89-188b47b5cc0d} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it: In scope SELECT CAST('{"x" : 1}', 'Object(\'json\')'). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54856) (comment: 02513_validate_data_types.sql) (query 2, line 4) (in query: select CAST('{"x" : 1}', 'Object(''json'')');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033935f4a 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000033933dfb 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c2ef375 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152410 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:01.626307 [ 6072 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it: In scope SELECT CAST('{"x" : 1}', 'Object(\'json\')'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033935f4a 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000033933dfb 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c2ef375 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152410 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:01.997407 [ 16390 ] {ef9f6c9b-2ba6-4cd5-8717-5afb9607ffa1} executeQuery: Code: 55. DB::Exception: Parametrized view can't be queried through a Merge table.: Child table: test_13.v (a3ec8ea1-7c9b-4b43-95c8-099d0c4a6d4a). (STORAGE_REQUIRES_PARAMETER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55332) (comment: 03322_view_over_parameterized_view.sql) (query 3, line 3) (in query: select * from vv;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageMerge.cpp:662: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x00000000387c3d64 5. ./build_docker/./src/Storages/StorageMerge.cpp:588: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x00000000387b1348 6. ./build_docker/./src/Storages/StorageMerge.cpp:1638: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x00000000387ed560 7. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003c4c99c7 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:49: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c4c9208 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c37a6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:02.001068 [ 16390 ] {} TCPHandler: Code: 55. DB::Exception: Parametrized view can't be queried through a Merge table.: Child table: test_13.v (a3ec8ea1-7c9b-4b43-95c8-099d0c4a6d4a). (STORAGE_REQUIRES_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageMerge.cpp:662: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x00000000387c3d64 5. ./build_docker/./src/Storages/StorageMerge.cpp:588: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x00000000387b1348 6. ./build_docker/./src/Storages/StorageMerge.cpp:1638: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x00000000387ed560 7. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003c4c99c7 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:49: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c4c9208 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c37a6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:02.154338 [ 18771 ] {f7e1c228-9c59-401b-afc3-69e9d7450c6c} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017,'). (CANNOT_PARSE_DATETIME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54800) (comment: 02457_parse_date_time_best_effort.sql) (query 11, line 11) (in query: select parseDateTimeBestEffort('01/12/2017,');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa051f0 5. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d12a3 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abf32 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:02.158279 [ 18771 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017,'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa051f0 5. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d12a3 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abf32 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:02.397780 [ 6072 ] {19c412e7-6b21-4ca6-af73-35796b1b5479} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54856) (comment: 02513_validate_data_types.sql) (query 3, line 5) (in query: desc file(nonexist.json, JSONEachRow, 'x Object(''json'')');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033935f4a 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003393785b 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ba94 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:02.402659 [ 6072 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Object('json')' because experimental Object type is not allowed. Set setting allow_experimental_object_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033935f4a 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003393785b 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ba94 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:02.912599 [ 6005 ] {e1bdde4c-25bb-4df9-983b-a316c4dbfd8b} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54174) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 43, line 46) (in query: SELECT t1.*, t2.* from t1 LEFT JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930800 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:02.918736 [ 6005 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930800 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:03.769905 [ 18771 ] {7e23e225-8c33-4ca6-92c4-875b2d38c008} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffortUS('18:31:44,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54800) (comment: 02457_parse_date_time_best_effort.sql) (query 12, line 12) (in query: select parseDateTimeBestEffortUS('18:31:44,,,, 31/12/2015');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffortUS(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa0d638 5. ./src/Functions/FunctionsConversion.h:1000: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0e56e3 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0b69c1 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:03.774670 [ 18771 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffortUS('18:31:44,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffortUS(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa0d638 5. ./src/Functions/FunctionsConversion.h:1000: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0e56e3 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0b69c1 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:03.818867 [ 6072 ] {66e8743d-eedc-40f5-a7d6-f12c913b82ed} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting: In scope SELECT CAST(1000000, 'LowCardinality(UInt64)'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54856) (comment: 02513_validate_data_types.sql) (query 5, line 8) (in query: select CAST(1000000, 'LowCardinality(UInt64)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x00000000339368ec 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000033933dfb 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c2ef375 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152410 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:03.823286 [ 6072 ] {} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting: In scope SELECT CAST(1000000, 'LowCardinality(UInt64)'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x00000000339368ec 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000033933dfb 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c2ef375 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152410 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:04.088904 [ 2997 ] {6dfe3957-bf17-484d-a652-8da48b905817} executeQuery: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55366) (comment: 01780_column_sparse_tuple.sql) (query 20, line 43) (in query: DETACH TABLE sparse_tuple;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d91d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.094420 [ 2997 ] {} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d91d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.155520 [ 18392 ] {79976236-3fe3-4924-8d54-83c024d322ef} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55462) (comment: 01132_max_rows_to_read.sql) (query 4, line 5) (in query: SELECT count() FROM numbers(30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003c45b5f5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c457ec2 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c453ed4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.206510 [ 16390 ] {acdab767-0358-4042-845d-82460ed59646} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55188) (comment: 01780_column_sparse_tuple.sql) (in query: DROP DATABASE IF EXISTS test_sxwpfr01 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.210008 [ 16390 ] {acdab767-0358-4042-845d-82460ed59646} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:04.223734 [ 18392 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003c45b5f5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c457ec2 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c453ed4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.339498 [ 6072 ] {5fa796fc-e17f-4041-a97f-dee99b5bd702} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54856) (comment: 02513_validate_data_types.sql) (query 6, line 9) (in query: desc file(nonexist.json, JSONEachRow, 'lc LowCardinality(UInt64)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x00000000339368ec 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003393785b 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ba94 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.343608 [ 6072 ] {} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt64) is prohibited by default due to expected negative impact on performance. It can be enabled with the `allow_suspicious_low_cardinality_types` setting. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x00000000339368ec 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003393785b 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ba94 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.712135 [ 18392 ] {7d9ac338-a69b-43c1-8e05-4277cb75302f} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55462) (comment: 01132_max_rows_to_read.sql) (query 7, line 8) (in query: SELECT count() FROM numbers(21);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003c45b5f5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c457ec2 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c453ed4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.716609 [ 18392 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 21.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003c45b5f5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c457ec2 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c453ed4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.730980 [ 6005 ] {26fd080c-99b5-41be-8250-4a7d2ac43bbb} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54174) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 50, line 53) (in query: SELECT t1.*, t2.* from t1 INNER JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930800 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.737937 [ 6005 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930800 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.752930 [ 18392 ] {d5242892-1bb0-4b19-a4f8-19098e4e5688} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55462) (comment: 01132_max_rows_to_read.sql) (query 8, line 10) (in query: -- check early exception if the estimated number of rows is high SELECT * FROM numbers(30);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003c45b5f5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c457ec2 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c453ed4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:04.758092 [ 18392 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 20.00, current rows: 30.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x000000003c45b5f5 7. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x000000003c457ec2 8. ./build_docker/./src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c453ed4 9. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:05.076339 [ 16390 ] {8d68b4c7-29d3-4222-9ade-264d2924ec22} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55522) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: DROP TABLE mutations_r1 SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:05.086646 [ 16390 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:05.211352 [ 18771 ] {c25ae702-cd7b-454d-b099-dc3fe570ad57} executeQuery: Code: 6. DB::Exception: Cannot parse string '18:31:44, 31/12/2015,' as DateTime: syntax error at position 20 (parsed just '18:31:44, 31/12/2015'): In scope SELECT parseDateTimeBestEffortUS('18:31:44, 31/12/2015,'). (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54800) (comment: 02457_parse_date_time_best_effort.sql) (query 13, line 13) (in query: select parseDateTimeBestEffortUS('18:31:44, 31/12/2015,');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0e5a3e 5. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0b69c1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:14:05.217148 [ 18771 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '18:31:44, 31/12/2015,' as DateTime: syntax error at position 20 (parsed just '18:31:44, 31/12/2015'): In scope SELECT parseDateTimeBestEffortUS('18:31:44, 31/12/2015,'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0e5a3e 5. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0b69c1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:14:05.717128 [ 6072 ] {e6921427-699c-42ec-bf1c-2b0cbefe1ce9} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('', 'FixedString(1000)'). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54856) (comment: 02513_validate_data_types.sql) (query 8, line 12) (in query: select CAST('', 'FixedString(1000)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000098c9f8d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033936513 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000033933dfb 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c2ef375 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152410 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:05.737869 [ 6072 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it: In scope SELECT CAST('', 'FixedString(1000)'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000098c9f8d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033936513 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000033933dfb 6. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c2ef375 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152410 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:05.743128 [ 16690 ] {cf6e8d90-ac5d-4278-8209-43fc9dcc28f2} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55558) (comment: 02921_database_filesystem_path_check.sql) (query 1, line 1) (in query: create database db_filesystem ENGINE=Filesystem('/etc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6d45 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:14:05.747413 [ 16690 ] {} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6d45 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:14:05.767319 [ 16690 ] {df7cae81-8e86-401d-a045-41be8bd1fcc3} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55558) (comment: 02921_database_filesystem_path_check.sql) (query 2, line 2) (in query: create database db_filesystem ENGINE=Filesystem('../../../../../../../../etc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6d45 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:14:05.771197 [ 16690 ] {} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6d45 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:14:05.938224 [ 16215 ] {0830ba5f-27fe-4fa2-a395-80ca77613301} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r2 (18579a2b-ead5-4580-acdb-a86c12c0666e)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55606) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: DROP TABLE mutations_r2 SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:05.943914 [ 16215 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_r2 (18579a2b-ead5-4580-acdb-a86c12c0666e)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:06.292994 [ 6072 ] {f01cfa0a-43fb-4913-a23d-5a9422646c4b} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54856) (comment: 02513_validate_data_types.sql) (query 9, line 13) (in query: desc file(nonexist.json, JSONEachRow, 'fs FixedString(1000)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000098c9f8d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033936513 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003393785b 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ba94 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:06.297010 [ 6072 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000098c9f8d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033936513 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003393785b 6. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:122: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002675ba94 7. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000003397076c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x000000003396cba5 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:06.457539 [ 6005 ] {01f3e926-b12b-4b53-9d83-d34d71c7a6e6} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54174) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 57, line 60) (in query: SELECT t1.*, t2.* from t1 RIGHT JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930800 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:06.462351 [ 6005 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930800 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:06.864428 [ 16199 ] {f89b3a27-0eef-40e1-80c3-8ef7b36132f1} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55688) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: DROP TABLE mutations_cleaner_r1 SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:06.875570 [ 16199 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:06.949885 [ 18771 ] {35c484d7-fbbd-4aac-8c6e-e334ff0203aa} executeQuery: Code: 6. DB::Exception: Cannot parse string '01/12/2017, 18:31:44,' as DateTime: syntax error at position 20 (parsed just '01/12/2017, 18:31:44'): In scope SELECT parseDateTimeBestEffort('01/12/2017, 18:31:44,'). (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54800) (comment: 02457_parse_date_time_best_effort.sql) (query 14, line 14) (in query: select parseDateTimeBestEffort('01/12/2017, 18:31:44,');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d15fe 5. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abf32 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:14:06.954544 [ 18771 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '01/12/2017, 18:31:44,' as DateTime: syntax error at position 20 (parsed just '01/12/2017, 18:31:44'): In scope SELECT parseDateTimeBestEffort('01/12/2017, 18:31:44,'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d15fe 5. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abf32 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:14:07.010165 [ 18771 ] {0f436f43-7483-4503-bb4f-d664e19e0d3c} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017, ,,,18:31:44'). (CANNOT_PARSE_DATETIME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54800) (comment: 02457_parse_date_time_best_effort.sql) (query 15, line 15) (in query: select parseDateTimeBestEffort('01/12/2017, ,,,18:31:44');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa051f0 5. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d12a3 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abf32 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:07.014144 [ 18771 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('01/12/2017, ,,,18:31:44'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa051f0 5. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d12a3 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abf32 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:07.062000 [ 18771 ] {c3388f25-d627-4b9e-a99b-d573e7a0eb8b} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('18:31:44 ,,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54800) (comment: 02457_parse_date_time_best_effort.sql) (query 16, line 16) (in query: select parseDateTimeBestEffort('18:31:44 ,,,,, 31/12/2015');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa051f0 5. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d12a3 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abf32 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:07.066160 [ 18771 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort('18:31:44 ,,,,, 31/12/2015'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa051f0 5. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d12a3 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abf32 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:07.891632 [ 16203 ] {071f2fbe-b3a0-4c4b-a5f5-caa3cced91ec} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r2 (3665afb5-6fe3-4d5a-9ae0-e3a8304e8768)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55794) (comment: 00652_replicated_mutations_zookeeper.sh) (query 1, line 1) (in query: DROP TABLE mutations_cleaner_r2 SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:07.897151 [ 16203 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r2 (3665afb5-6fe3-4d5a-9ae0-e3a8304e8768)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:08.149136 [ 6005 ] {e9b4d805-e972-4de7-b680-47c9ded5f007} executeQuery: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54174) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 64, line 67) (in query: SELECT t1.*, t2.* from t1 FULL JOIN t2 ON t1.key = t2.key and t1.c ORDER BY (t1.key, t1.attr, t2.key, t2.attr) SETTINGS query_plan_use_new_logical_join_step = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930800 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:08.153775 [ 6005 ] {} TCPHandler: Code: 403. DB::Exception: Expected logical expression in JOIN ON section, got unexpected column '__table1.c' of type 'UInt64'. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/JoinUtils.cpp:429: DB::JoinCommon::checkTypesOfMasks(DB::Block const&, String const&, DB::Block const&, String const&)::$_0::operator()(DB::Block const&, String const&) const @ 0x0000000032e0a6fe 5. ./build_docker/./src/Interpreters/JoinUtils.cpp:433: DB::JoinCommon::checkTypesOfKeys(DB::Block const&, std::vector> const&, String const&, DB::Block const&, std::vector> const&, String const&) @ 0x0000000032e09fed 6. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1044: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9947 7. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:425: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930800 8. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 10. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 11. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c8885e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:08.722868 [ 17376 ] {c3723021-b403-49c9-b5cc-c2cd8296b378} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55298) (comment: 02864_statistics_bug_69589.sql) (in query: DROP DATABASE IF EXISTS test_67mizf8t SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:08.730696 [ 17376 ] {c3723021-b403-49c9-b5cc-c2cd8296b378} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:08.816028 [ 3733 ] {2630248b-b368-40b2-beae-4bcfd6e8bacc::20191002_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/263/2630248b-b368-40b2-beae-4bcfd6e8bacc/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:09.360712 [ 16189 ] {05e1cf4b-633c-40a3-9c84-979ec3199633} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55286) (comment: 00652_replicated_mutations_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_u21noyth SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:14:09.364281 [ 16189 ] {05e1cf4b-633c-40a3-9c84-979ec3199633} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:09.423418 [ 16199 ] {3f2f1e64-b7e3-41ac-9a69-8d024b094c56} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `ArrLen` in scope SELECT dummy AS x, plus(ignore(ignore(ignore(ignore('-922337203.6854775808', ignore(NULL)), ArrLen = 256, ignore(100, Arr.C3, ignore(NULL), (SELECT 10.000100135803223, count(*) FROM system.time_zones) > NULL)))), dummy, 65535) AS dummy ORDER BY ignore(-2) ASC, identity(x) DESC NULLS FIRST. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55700) (comment: 01247_some_msan_crashs_from_22517.sql) (query 2, line 3) (in query: SELECT x FROM (SELECT dummy AS x, plus(ignore(ignore(ignore(ignore('-922337203.6854775808', ignore(NULL)), ArrLen = 256, ignore(100, Arr.C3, ignore(NULL), (SELECT 10.000100135803223, count(*) FROM system.time_zones) > NULL)))), dummy, 65535) AS dummy ORDER BY ignore(-2) ASC, identity(x) DESC NULLS FIRST) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1243: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030447274 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1494: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449c4e 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5354: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7c72 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 2025.11.13 09:14:09.429367 [ 16199 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `ArrLen` in scope SELECT dummy AS x, plus(ignore(ignore(ignore(ignore('-922337203.6854775808', ignore(NULL)), ArrLen = 256, ignore(100, Arr.C3, ignore(NULL), (SELECT 10.000100135803223, count(*) FROM system.time_zones) > NULL)))), dummy, 65535) AS dummy ORDER BY ignore(-2) ASC, identity(x) DESC NULLS FIRST. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1243: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030447274 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1494: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449c4e 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5354: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7c72 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 31. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 2025.11.13 09:14:10.352516 [ 19606 ] {6ebc434e-4dc3-4537-985d-de66395525b8} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20191002_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/263/2630248b-b368-40b2-beae-4bcfd6e8bacc/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a4a64d3 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991221 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 . (UNFINISHED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55800) (comment: 01414_mutations_and_errors.sql) (query 6, line 19) (in query: ALTER TABLE mutation_table MODIFY COLUMN value UInt64 SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a4a64d3 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991221 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:10.358266 [ 19606 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_3.txt' with part '20191002_2_2_0' reason: 'Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/263/2630248b-b368-40b2-beae-4bcfd6e8bacc/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a4a64d3 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991221 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a4a64d3 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991221 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:10.367010 [ 3733 ] {2630248b-b368-40b2-beae-4bcfd6e8bacc::20191002_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/263/2630248b-b368-40b2-beae-4bcfd6e8bacc/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002ca5118a 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3bfe7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e9c3 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003388fdbb 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039ea0417 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000039eca0dc 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f2830e 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:10.367847 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2630248b-b368-40b2-beae-4bcfd6e8bacc::20191002_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/263/2630248b-b368-40b2-beae-4bcfd6e8bacc/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002ca5118a 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3bfe7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e9c3 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003388fdbb 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039ea0417 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000039eca0dc 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f2830e 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:10.688441 [ 3730 ] {2630248b-b368-40b2-beae-4bcfd6e8bacc::20191002_2_2_0_3} MutatePlainMergeTreeTask: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/263/2630248b-b368-40b2-beae-4bcfd6e8bacc/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:10.689487 [ 3730 ] {2630248b-b368-40b2-beae-4bcfd6e8bacc::20191002_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/263/2630248b-b368-40b2-beae-4bcfd6e8bacc/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002ca5118a 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3bfe7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e9c3 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003388fdbb 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039ea0417 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000039eca0dc 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f2830e 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:10.690344 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2630248b-b368-40b2-beae-4bcfd6e8bacc::20191002_2_2_0_3}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value :: 2, 'UInt64' :: 3) -> _CAST(value, 'UInt64') UInt64 : 4': (while reading from part /var/lib/clickhouse/store/263/2630248b-b368-40b2-beae-4bcfd6e8bacc/20191002_2_2_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002ca5118a 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3bfe7 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e9c3 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 14. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 15. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 21. ./build_docker/./src/Interpreters/inplaceBlockConversions.cpp:187: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x000000003388fdbb 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:313: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039ea0417 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:1338: DB::MergeTreeRangeReader::executeActionsBeforePrewhere(DB::MergeTreeRangeReader::ReadResult&, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&, DB::Block const&, unsigned long) const @ 0x0000000039eca0dc 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:74: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f2830e 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 26. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 27. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:10.749253 [ 10177 ] {da1557af-ac5f-4f8a-8a5d-3bd1036a673e} executeQuery: Code: 469. DB::Exception: Constraint `c` for table test_13.default_constraints (bd52c2d0-d054-41e1-9acf-ba846b327c37) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55906) (comment: 01286_constraints_on_default.sql) (query 3, line 9) (in query: INSERT INTO default_constraints (x) SELECT number FROM system.numbers LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:14:10.760753 [ 10177 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table test_13.default_constraints (bd52c2d0-d054-41e1-9acf-ba846b327c37) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:10.811407 [ 10177 ] {e7ed9678-b6c8-4d60-91eb-574b5fc4d6ae} executeQuery: Code: 469. DB::Exception: Constraint `c` for table test_13.default_constraints (bd52c2d0-d054-41e1-9acf-ba846b327c37) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55906) (comment: 01286_constraints_on_default.sql) (query 4, line 10) (in query: INSERT INTO default_constraints (x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:14:10.826850 [ 10177 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table test_13.default_constraints (bd52c2d0-d054-41e1-9acf-ba846b327c37) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:14:10.868596 [ 16200 ] {ce914d27-a357-42a3-bceb-cac314d35c33} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55826) (comment: 01412_group_array_moving_shard.sql) (query 11, line 17) (in query: SELECT groupArrayMovingSum(0)(1) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:14:10.872962 [ 16200 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:272: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a42686 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:14:11.547502 [ 10177 ] {c9b5e646-95f0-4af2-a8f4-c945245ba81a} executeQuery: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_1a3a6f53-c31a-4d6f-b272-7c363c4d43c8` (1a3a6f53-c31a-4d6f-b272-7c363c4d43c8) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55906) (comment: 01286_constraints_on_default.sql) (query 9, line 25) (in query: INSERT INTO default_constraints (x) SELECT number FROM system.numbers LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:14:11.555953 [ 10177 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_1a3a6f53-c31a-4d6f-b272-7c363c4d43c8` (1a3a6f53-c31a-4d6f-b272-7c363c4d43c8) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:11.606270 [ 10177 ] {f2f18d79-1c93-4d45-ae22-a6fab9ce50a0} executeQuery: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_1a3a6f53-c31a-4d6f-b272-7c363c4d43c8` (1a3a6f53-c31a-4d6f-b272-7c363c4d43c8) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55906) (comment: 01286_constraints_on_default.sql) (query 10, line 26) (in query: INSERT INTO default_constraints (x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:14:11.614345 [ 10177 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_1a3a6f53-c31a-4d6f-b272-7c363c4d43c8` (1a3a6f53-c31a-4d6f-b272-7c363c4d43c8) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:14:12.159075 [ 16200 ] {8ac2ea74-f12c-4566-84c6-307526d202e6} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55826) (comment: 01412_group_array_moving_shard.sql) (query 12, line 18) (in query: SELECT groupArrayMovingSum(0.)(1) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a43613 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:14:12.163738 [ 16200 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a43613 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:14:12.194169 [ 16200 ] {36b03a54-f948-4735-af6d-59f87f076e12} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55826) (comment: 01412_group_array_moving_shard.sql) (query 13, line 19) (in query: SELECT groupArrayMovingSum(0.1)(1) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a43613 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:14:12.198800 [ 16200 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a43613 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:14:12.237225 [ 16200 ] {75888e9f-53c7-401b-b5cb-ce781418bce6} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55826) (comment: 01412_group_array_moving_shard.sql) (query 14, line 20) (in query: SELECT groupArrayMovingSum(0.1)(1) FROM remote('127.0.0.{1,2}', numbers(100));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a43613 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:14:12.242566 [ 16200 ] {} TCPHandler: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:268: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMoving(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025a43613 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:14:13.269540 [ 16230 ] {31c5c95c-bad7-449a-aa22-0357eea34788} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=855). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55714) (comment: 02900_add_subtract_interval_with_string_date.sql) (query 65, line 73) (in query: SELECT subtractYears('2023-10-22', materialize(1)), subtractYears('2023-10-22 12:34:56.123', materialize(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:13.278175 [ 16230 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=855). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:15.989976 [ 18391 ] {e65ee75e-502a-4f2b-b8af-8199f3f91b52} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38374) (comment: 00927_disable_hyperscan.sql) (query 5, line 10) (in query: SELECT multiMatchAny(arrayJoin(['hello', 'world', 'hellllllllo', 'wororld', 'abc']), ['hel+o', 'w(or)*ld']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107ed56 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:15.993889 [ 18391 ] {} TCPHandler: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107ed56 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:16.397470 [ 16200 ] {538b67c6-1b6a-4ad9-a949-e39ad6f31549} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 10000000000 is not in range (-2147483648, 2147483647): In scope SELECT groupArrayMovingSum(256)(toDecimal32(1000000000, 1)) FROM numbers(300). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55826) (comment: 01412_group_array_moving_shard.sql) (query 19, line 25) (in query: SELECT groupArrayMovingSum(256)(toDecimal32(1000000000, 1)) FROM numbers(300);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42eff7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c00e 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce67dc1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce4bccf 8. ./src/Core/callOnTypeIndex.h:254: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ea4d 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:14:16.405540 [ 16200 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 10000000000 is not in range (-2147483648, 2147483647): In scope SELECT groupArrayMovingSum(256)(toDecimal32(1000000000, 1)) FROM numbers(300). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42eff7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c00e 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce67dc1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce4bccf 8. ./src/Core/callOnTypeIndex.h:254: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ea4d 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:14:16.434626 [ 19172 ] {129863ad-da6b-49b2-b50d-48e71799c190} executeQuery: Code: 6. DB::Exception: Cannot parse string '61f0c404-5cb3-11e7-907b-a6006ad3dba0T' as UUID: syntax error at position 36 (parsed just '61f0c404-5cb3-11e7-907b-a6006ad3dba0'): In scope SELECT toUUID('61f0c404-5cb3-11e7-907b-a6006ad3dba0T'). (CANNOT_PARSE_TEXT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38388) (comment: 01528_to_uuid_or_null_or_zero.sql) (query 3, line 4) (in query: SELECT toUUID('61f0c404-5cb3-11e7-907b-a6006ad3dba0T');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002cd9581c 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cd84c87 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94b7c3 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c99cb5d 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c99baa2 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:14:16.439784 [ 19172 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '61f0c404-5cb3-11e7-907b-a6006ad3dba0T' as UUID: syntax error at position 36 (parsed just '61f0c404-5cb3-11e7-907b-a6006ad3dba0'): In scope SELECT toUUID('61f0c404-5cb3-11e7-907b-a6006ad3dba0T'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x0000000008f1a486 4. ./src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000002cd9581c 5. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cd84c87 6. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94b7c3 7. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c99cb5d 8. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c99baa2 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 10. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:14:16.581640 [ 18700 ] {b4b73c6f-f2ad-41a1-aa84-1176d195595b} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01416_clear_column_pk.sql) (in query: /* ddl_entry=query-0000000003 */ ALTER TABLE test_ewqq89g5.table_with_pk_clear (CLEAR COLUMN key1 IN PARTITION tuple())), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3785: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039925c7a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:14:16.592673 [ 18700 ] {b4b73c6f-f2ad-41a1-aa84-1176d195595b} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38412) (comment: 01416_clear_column_pk.sql) (query 4, line 14) (in query: ALTER TABLE table_with_pk_clear CLEAR COLUMN key1 IN PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3785: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039925c7a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:14:16.596093 [ 18700 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP key key1 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3785: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039925c7a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:14:17.013997 [ 18700 ] {5cdbbefc-09c3-4bfd-8d8a-94b5a1d4b947} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01416_clear_column_pk.sql) (in query: /* ddl_entry=query-0000000004 */ ALTER TABLE test_ewqq89g5.table_with_pk_clear (CLEAR COLUMN key2 IN PARTITION tuple())), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3785: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039925c7a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:14:17.027610 [ 18700 ] {5cdbbefc-09c3-4bfd-8d8a-94b5a1d4b947} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38412) (comment: 01416_clear_column_pk.sql) (query 6, line 18) (in query: ALTER TABLE table_with_pk_clear CLEAR COLUMN key2 IN PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3785: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039925c7a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:14:17.031446 [ 18700 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP key key2 column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3785: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039925c7a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:14:17.501772 [ 18391 ] {81cf07bf-628a-4ec7-9b30-b3439c535ea4} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38374) (comment: 00927_disable_hyperscan.sql) (query 6, line 11) (in query: SELECT multiMatchAny(arrayJoin(['hello', 'world', 'hellllllllo', 'wororld', 'abc']), materialize(['hel+o', 'w(or)*ld']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107f100 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:17.506450 [ 18391 ] {} TCPHandler: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107f100 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:18.037729 [ 18721 ] {96a525de-5ad5-4b27-a3b0-cc7607943553} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1073.884397 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38514) (comment: 01039_mergetree_exec_time.sql) (query 4, line 4) (in query: select sum(sleep(0.1)) from tab settings max_block_size = 1, max_execution_time=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:14:18.049152 [ 18721 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1073.884397 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:18.177074 [ 5803 ] {f2aee079-32a5-4907-b284-b6c370c9708c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1094.394679 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43370) (comment: 01039_mergetree_exec_time.sql) (query 4, line 4) (in query: SELECT sum(sleep(0.1)) AS `sum(sleep(0.1))` FROM `test_9`.`tab` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:14:18.185719 [ 5803 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1094.394679 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:19.198829 [ 18391 ] {7e391d50-70e2-4166-87d3-086070a8a7a4} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38374) (comment: 00927_disable_hyperscan.sql) (query 7, line 13) (in query: SELECT multiMatchAllIndices(arrayJoin(['hello', 'world', 'hellllllllo', 'wororld', 'abc']), ['hel+o', 'w(or)*ld']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6da7e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:19.202657 [ 18391 ] {} TCPHandler: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6da7e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:20.052967 [ 18131 ] {1256bc62-4b89-4000-bf17-f8de4f99a875} executeQuery: Code: 574. DB::Exception: Too many bytes pending for async INSERT: 5.55 KiB (bytes_to_throw_insert=1.00 B). (DISTRIBUTED_TOO_MANY_PENDING_BYTES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38574) (comment: 01670_distributed_bytes_to_throw_insert.sql) (query 7, line 11) (in query: -- second will fail, because of bytes_to_throw_insert=1 -- (previous block definitelly takes more, since it has header) insert into dist_01670 select * from numbers(1) settings prefer_localhost_replica=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1862: DB::StorageDistributed::delayInsertOrThrowIfNeeded() const @ 0x00000000384aa410 5. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:170: DB::DistributedSink::consume(DB::Chunk&) @ 0x00000000394a3fa1 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:14:20.063069 [ 18131 ] {} TCPHandler: Code: 574. DB::Exception: Too many bytes pending for async INSERT: 5.55 KiB (bytes_to_throw_insert=1.00 B). (DISTRIBUTED_TOO_MANY_PENDING_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1862: DB::StorageDistributed::delayInsertOrThrowIfNeeded() const @ 0x00000000384aa410 5. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:170: DB::DistributedSink::consume(DB::Chunk&) @ 0x00000000394a3fa1 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:20.210298 [ 16223 ] {89c2a3ad-3ca3-415f-bd43-56ac90b35ea5} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 9. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:20.245163 [ 18106 ] {cf002ce7-0e6e-40ba-9e29-1210520130df} executeQuery: Code: 69. DB::Exception: Too many digits (10 > 9) in decimal value: In scope SELECT '1000000000' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 4, line 5) (in query: SELECT '1000000000' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002eb50b9f 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f468d3e 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e1a3e 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002ce8ec79 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5c65e 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ea03 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:20.249833 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Too many digits (10 > 9) in decimal value: In scope SELECT '1000000000' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002eb50b9f 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f468d3e 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e1a3e 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002ce8ec79 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5c65e 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ea03 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:20.274681 [ 18106 ] {9c052700-58d3-4183-b057-1b8282af2702} executeQuery: Code: 69. DB::Exception: Too many digits (10 > 9) in decimal value: In scope SELECT '-1000000000' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 5, line 6) (in query: SELECT '-1000000000' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002eb50b9f 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f468d3e 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e1a3e 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002ce8ec79 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5c65e 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ea03 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:20.280726 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Too many digits (10 > 9) in decimal value: In scope SELECT '-1000000000' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002eb50b9f 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f468d3e 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e1a3e 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002ce8ec79 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5c65e 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ea03 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:20.304611 [ 16223 ] {89c2a3ad-3ca3-415f-bd43-56ac90b35ea5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38590) (comment: 00749_inner_join_of_unnamed_subqueries.sql) (query 8, line 14) (in query: SELECT APIKey, ConversionEventValue FROM left_table AS left_table ALL INNER JOIN ( SELECT * FROM ( SELECT APIKey, EventValueForPostback AS ConversionEventValue FROM right_table AS right_table ) ALL INNER JOIN ( SELECT APIKey FROM left_table as left_table GROUP BY APIKey ) USING (APIKey) ) USING (APIKey);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 9. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:14:20.359610 [ 16223 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 9. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:14:20.429989 [ 18391 ] {82c9e892-7733-4e8f-84ac-582b4d709787} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38374) (comment: 00927_disable_hyperscan.sql) (query 8, line 14) (in query: SELECT multiMatchAllIndices(arrayJoin(['hello', 'world', 'hellllllllo', 'wororld', 'abc']), materialize(['hel+o', 'w(or)*ld']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6de1f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:20.434319 [ 18391 ] {} TCPHandler: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6de1f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:20.450760 [ 16207 ] {5d3ec2db-bb5d-4a4b-810b-b255db7334fa} executeQuery: Code: 558. DB::Exception: Expected ALL or DISTINCT in SelectWithUnion query, because setting (union_default_mode) is empty: While processing SELECT 1 UNION SELECT 1 UNION ALL SELECT 1. (EXPECTED_ALL_OR_DISTINCT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38628) (comment: 01732_union_and_union_all.sql) (query 1, line 1) (in query: select 1 UNION select 1 UNION ALL select 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:74: DB::NormalizeSelectWithUnionQueryMatcher::visit(DB::ASTSelectWithUnionQuery&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x0000000032f3de54 5. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:36: DB::NormalizeSelectWithUnionQueryMatcher::visit(std::shared_ptr&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x0000000032f3ab5e 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002f973d35 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338283c6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:20.455695 [ 16207 ] {} TCPHandler: Code: 558. DB::Exception: Expected ALL or DISTINCT in SelectWithUnion query, because setting (union_default_mode) is empty: While processing SELECT 1 UNION SELECT 1 UNION ALL SELECT 1. (EXPECTED_ALL_OR_DISTINCT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:74: DB::NormalizeSelectWithUnionQueryMatcher::visit(DB::ASTSelectWithUnionQuery&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x0000000032f3de54 5. ./build_docker/./src/Interpreters/NormalizeSelectWithUnionQueryVisitor.cpp:36: DB::NormalizeSelectWithUnionQueryMatcher::visit(std::shared_ptr&, DB::NormalizeSelectWithUnionQueryMatcher::Data&) @ 0x0000000032f3ab5e 6. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000002f973d35 7. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338283c6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:23.069106 [ 18106 ] {e9342188-130f-4c40-b07d-be3157b7dba8} executeQuery: Code: 69. DB::Exception: Too many digits (19 > 18) in decimal value: In scope SELECT '1000000000000000000' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 6, line 7) (in query: SELECT '1000000000000000000' AS x, toDecimal64(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002eb5230c 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f46a03e 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e445e 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cedf7d8 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ceac8fe 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f463 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:23.077722 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Too many digits (19 > 18) in decimal value: In scope SELECT '1000000000000000000' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002eb5230c 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f46a03e 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e445e 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cedf7d8 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ceac8fe 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f463 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:23.172993 [ 18106 ] {69f7a87f-23f0-40c5-b646-13d7e2e9534a} executeQuery: Code: 69. DB::Exception: Too many digits (19 > 18) in decimal value: In scope SELECT '-1000000000000000000' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 7, line 8) (in query: SELECT '-1000000000000000000' AS x, toDecimal64(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002eb5230c 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f46a03e 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e445e 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cedf7d8 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ceac8fe 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f463 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:23.177605 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Too many digits (19 > 18) in decimal value: In scope SELECT '-1000000000000000000' AS x, toDecimal64(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>(DB::ReadBuffer&, DB::Decimal&, unsigned int&, int&, bool) @ 0x000000002eb5230c 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f46a03e 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e445e 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cedf7d8 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ceac8fe 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f463 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:25.610819 [ 16344 ] {ab23be26-4051-4049-b481-c8b64195a6c7} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 9. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003c1fae0e 13. ./build_docker/./src/Planner/Planner.cpp:249: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000032be2522 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd625b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:25.620273 [ 16344 ] {ab23be26-4051-4049-b481-c8b64195a6c7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35976) (comment: 03325_distributed_join_json_array_subcolumns.sql) (query 8, line 24) (in query: SELECT count() FROM test_distr as left GLOBAL INNER JOIN test_distr as right on left.id = right.id WHERE has(right.data.arr1, 's3') AND has(right.data.arr2, 42);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 9. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003c1fae0e 13. ./build_docker/./src/Planner/Planner.cpp:249: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000032be2522 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd625b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:25.628713 [ 16344 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 9. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000003c1fae0e 13. ./build_docker/./src/Planner/Planner.cpp:249: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000032be2522 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd625b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:25.934550 [ 17228 ] {4fcb25f2-62ee-40a9-a7b1-4bf0aa8d7b95} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `value_element` in scope SELECT id, value_element, value FROM test_table ARRAY JOIN [[1, 2, 3]] AS value_element, value_element AS value. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36024) (comment: 02521_analyzer_array_join_crash.sql) (query 5, line 12) (in query: -- { echoOn } SELECT id, value_element, value FROM test_table ARRAY JOIN [[1,2,3]] AS value_element, value_element AS value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5038: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b6604 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5371: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7840 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:14:25.939285 [ 17228 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `value_element` in scope SELECT id, value_element, value FROM test_table ARRAY JOIN [[1, 2, 3]] AS value_element, value_element AS value. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5038: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b6604 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5371: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7840 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:14:26.044057 [ 18106 ] {c0b15bec-068c-4f71-b537-d6e066a6abc8} executeQuery: Code: 69. DB::Exception: Too many digits (39 > 38) in decimal value: In scope SELECT '100000000000000000000000000000000000000' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 8, line 9) (in query: SELECT '100000000000000000000000000000000000000' AS x, toDecimal128(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x000000002eb53bf1 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000002f46b3b4 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e7420 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cf30e59 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cefd21e 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94fec3 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:26.048876 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Too many digits (39 > 38) in decimal value: In scope SELECT '100000000000000000000000000000000000000' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x000000002eb53bf1 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000002f46b3b4 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e7420 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cf30e59 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cefd21e 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94fec3 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:26.074147 [ 18106 ] {261e2ddf-bcf9-4803-b97d-bc3b9de54b33} executeQuery: Code: 69. DB::Exception: Too many digits (39 > 38) in decimal value: In scope SELECT '-100000000000000000000000000000000000000' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 9, line 10) (in query: SELECT '-100000000000000000000000000000000000000' AS x, toDecimal128(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x000000002eb53bf1 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000002f46b3b4 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e7420 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cf30e59 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cefd21e 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94fec3 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:26.113195 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Too many digits (39 > 38) in decimal value: In scope SELECT '-100000000000000000000000000000000000000' AS x, toDecimal128(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/IO/readDecimalText.h:93: bool DB::readDigits>>(DB::ReadBuffer&, DB::Decimal>&, unsigned int&, int&, bool) @ 0x000000002eb53bf1 5. ./src/IO/readDecimalText.h:154: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000002f46b3b4 6. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e7420 7. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cf30e59 8. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cefd21e 9. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94fec3 10. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 11. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 2025.11.13 09:14:26.784035 [ 6005 ] {83ed348b-3087-43ce-8465-d5b40e9069ff} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54174) (comment: 03006_join_on_inequal_expression_fast.gen.sql) (query 141, line 144) (in query: SELECT t1.*, t2.* FROM t1 INNER ANY JOIN t2 ON (t1.a < t2.a OR lower(t1.attr) == lower(t2.attr)) AND t1.key = t2.key ORDER BY (t1.key, t1.attr, t2.key, t2.attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eeed2a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 12. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6c57c1 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ee4a84 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039ee43c9 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039ba06ba 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b8f2f5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:277: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b5e2 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:76: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3f962b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c3564d3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:14:26.806609 [ 6005 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eeed2a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 12. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6c57c1 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ee4a84 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039ee43c9 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039ba06ba 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b8f2f5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:277: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b5e2 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:76: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3f962b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c3564d3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:28.038264 [ 17228 ] {418e9202-4198-4de3-9664-f86ef2b90774} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByChar'. Expected: const String, got: String: In scope x -> splitByChar(x, elem). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36024) (comment: 02521_analyzer_array_join_crash.sql) (query 8, line 20) (in query: SELECT arrayFilter(x -> notEmpty(concat(x)), [NULL, NULL]) FROM system.one ARRAY JOIN [1048577] AS elem ARRAY JOIN arrayMap(x -> splitByChar(x, elem), ['']) AS unused;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6293ae 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2672: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000003049c304 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3436: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046dfdb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5038: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b6604 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5371: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7840 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:28.043827 [ 17228 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByChar'. Expected: const String, got: String: In scope x -> splitByChar(x, elem). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionTokens::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6293ae 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2672: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000003049c304 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3436: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046dfdb 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5038: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b6604 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5371: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7840 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:28.059787 [ 16354 ] {42f8528c-4c53-4740-a33f-59cc5c82a02d} executeQuery: Code: 479. DB::Exception: Unknown disk name __un_exists_disk while execute function filesystemCapacity: In scope SELECT filesystemCapacity('__un_exists_disk'). (UNKNOWN_DISK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36052) (comment: 02457_filesystem_function.sql) (query 3, line 6) (in query: select filesystemCapacity('__un_exists_disk');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000d38ebcd 4. DB::(anonymous namespace)::FilesystemImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ece4ae0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:14:28.066572 [ 16354 ] {} TCPHandler: Code: 479. DB::Exception: Unknown disk name __un_exists_disk while execute function filesystemCapacity: In scope SELECT filesystemCapacity('__un_exists_disk'). (UNKNOWN_DISK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000d38ebcd 4. DB::(anonymous namespace)::FilesystemImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ece4ae0 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:14:28.413335 [ 18106 ] {c34cf957-e361-4d5d-a772-9dfa88ce1466} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '1'e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '1' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 10, line 11) (in query: SELECT '1' AS x, toDecimal32(x, 9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f469057 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e1a3e 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002ce8ec79 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5c65e 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ea03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:28.419256 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '1'e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '1' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f469057 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e1a3e 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002ce8ec79 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5c65e 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ea03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:28.508549 [ 18106 ] {42e68263-1a15-4ace-b46f-3467688e654a} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '-1' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 11, line 12) (in query: SELECT '-1' AS x, toDecimal32(x, 9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f469057 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e1a3e 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002ce8ec79 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5c65e 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ea03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:28.513079 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e0. Expected to read decimal with scale 9 and precision 9: In scope SELECT '-1' AS x, toDecimal32(x, 9). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f469057 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e1a3e 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002ce8ec79 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5c65e 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ea03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:29.395360 [ 16693 ] {9cc42f9d-31e3-4d78-ba3d-d6d0c69bef7f} executeQuery: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is no need to merge parts according to merge selector algorithm. (CANNOT_ASSIGN_OPTIMIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36140) (comment: 03001_consider_lwd_when_merge.sql) (query 6, line 12) (in query: OPTIMIZE TABLE lwd_merge;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1725: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e9ce9 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033957419 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:14:29.399618 [ 16693 ] {} TCPHandler: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is no need to merge parts according to merge selector algorithm. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1725: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e9ce9 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033957419 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:14:30.140181 [ 16693 ] {9210007e-360b-4d5e-9c81-9e6b6e58dec7} executeQuery: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is no need to merge parts according to merge selector algorithm. (CANNOT_ASSIGN_OPTIMIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36140) (comment: 03001_consider_lwd_when_merge.sql) (query 9, line 17) (in query: OPTIMIZE TABLE lwd_merge;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1725: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e9ce9 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033957419 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:14:30.144645 [ 16693 ] {} TCPHandler: Code: 388. DB::Exception: Cannot OPTIMIZE table: There is no need to merge parts according to merge selector algorithm. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1725: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e9ce9 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033957419 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:14:31.053814 [ 18376 ] {9e5468ce-db8d-43a8-9579-e05fb0a9d7f8} executeQuery: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): cityHash64(globalIn(materialize(0), (NULL, -2147483648, -9223372036854775808)), nan, 1024, _CAST(NULL, 'Nullable(Nothing)'), materialize(1.000100016593933), 0, _CAST(NULL, 'Nullable(Nothing)')). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36182) (comment: 03234_evaluate_constant_analyzer.sql) (query 1, line 1) (in query: SELECT count() FROM numbers(cityHash64(materialize(toLowCardinality(toNullable(0))) GLOBAL IN (NULL, -2147483648, -9223372036854775808), nan, 1024, NULL, materialize(1.000100016593933), 0, NULL), 4) AS n1, numbers(3) AS n2, numbers(6) AS n3 GROUP BY (NULL, cityHash64(inf, -2147483648, toLowCardinality(16), NULL, 10.000100135803223), cityHash64(1.1754943508222875e-38, NULL, NULL, NULL), 2147483647), cityHash64(0., 3, NULL, NULL, 10000000000., NULL, NULL) SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:171: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000337b4934 5. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000337b75b3 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x0000000026717137 7. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026715a87 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5149: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b792f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:14:31.059609 [ 18376 ] {} TCPHandler: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): cityHash64(globalIn(materialize(0), (NULL, -2147483648, -9223372036854775808)), nan, 1024, _CAST(NULL, 'Nullable(Nothing)'), materialize(1.000100016593933), 0, _CAST(NULL, 'Nullable(Nothing)')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:171: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000337b4934 5. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000337b75b3 6. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x0000000026717137 7. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026715a87 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 9. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5149: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b792f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:14:31.356955 [ 18106 ] {bc3aa7f8-b9bd-418d-ab10-279fcfe02dc1} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '1'e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '1' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 12, line 13) (in query: SELECT '1' AS x, toDecimal64(x, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f46a3df 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e445e 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cedf7d8 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ceac8fe 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f463 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:31.362680 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '1'e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '1' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f46a3df 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e445e 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cedf7d8 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ceac8fe 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f463 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:31.388746 [ 18106 ] {dd610cac-4ca7-4b3a-a16f-22ffdbe25a75} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '-1' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 13, line 14) (in query: SELECT '-1' AS x, toDecimal64(x, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f46a3df 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e445e 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cedf7d8 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ceac8fe 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f463 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:31.392979 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e0. Expected to read decimal with scale 18 and precision 18: In scope SELECT '-1' AS x, toDecimal64(x, 18). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f46a3df 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e445e 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::NameToDecimal64, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cedf7d8 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ceac8fe 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f463 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:32.424799 [ 6028 ] {78154c22-ca85-4007-8cac-cc6eb7ef2d4b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37910) (comment: 01825_type_json_sparse.sql) (query 2, line 5) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:32.431540 [ 6028 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:32.744506 [ 18149 ] {0cccd653-3d2b-482b-b1d7-764778286cf8} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37866) (comment: 02516_projections_and_context.sql) (query 4, line 4) (in query: set enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:32.749551 [ 18149 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:34.814002 [ 18106 ] {86477801-f297-417d-8c64-097fb7ac18d0} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '1'e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '1' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 14, line 15) (in query: SELECT '1' AS x, toDecimal128(x, 38);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000002f46b9e6 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e7420 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cf30e59 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cefd21e 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94fec3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:34.823324 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '1'e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '1' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000002f46b9e6 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e7420 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cf30e59 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cefd21e 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94fec3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:34.880532 [ 18106 ] {988588ba-0b0b-4d0b-9970-83da3fe5c771} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '-1' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 15, line 16) (in query: SELECT '-1' AS x, toDecimal128(x, 38);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000002f46b9e6 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e7420 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cf30e59 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cefd21e 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94fec3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:34.890204 [ 18106 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: '-1'e0. Expected to read decimal with scale 38 and precision 38: In scope SELECT '-1' AS x, toDecimal128(x, 38). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText>, void>(DB::ReadBuffer&, DB::Decimal>&, unsigned int, unsigned int&, bool) @ 0x000000002f46b9e6 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>>::readText(DB::Decimal>&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e7420 6. ./src/Functions/FunctionsConversion.h:1014: COW::immutable_ptr DB::detail::ConvertThroughParsing>>, DB::detail::NameToDecimal128, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002cf30e59 7. ./src/Functions/FunctionsConversion.h:1580: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cefd21e 8. ./src/Core/callOnTypeIndex.h:280: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94fec3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:35.073185 [ 16352 ] {01986bf6-1c63-4ab2-b0f7-5d4df3a80cfe} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37968) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:35.081837 [ 10181 ] {0b47a74f-280a-427d-aa64-62b3a1de0e25} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37942) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:35.090737 [ 16352 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:35.122302 [ 10181 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:35.139162 [ 16355 ] {eb95a329-6cc6-4412-abd3-855dde378c48} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38002) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:35.166910 [ 16355 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:35.208970 [ 16192 ] {} TCPHandler: Code: 394. DB::Exception: Query '28f16883-7332-4b12-acfe-bfe55cddd601' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033837852 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:14:35.232404 [ 16446 ] {92e31668-d204-4074-8eb9-30d488955dae} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38142) (comment: 01825_type_json_1.sql) (query 1, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:35.236442 [ 18772 ] {88fb5806-3824-4e04-996c-e8e47fbc9738} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37838) (comment: 02963_msan_agg_addBatchLookupTable8.sql) (query 1, line 1) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/58727 SELECT number % 2 AS even, aggThrow(number) FROM numbers(10) GROUP BY even;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAggThrow.cpp:71: DB::(anonymous namespace)::AggregateFunctionThrow::create(char*) const @ 0x0000000025daa3b9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:811: void DB::Aggregator::createAggregateStates(char*&) const @ 0x0000000031e7dc08 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1087: void std::__function::__policy_invoker::__call_impl[abi:ne190107], FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const::'lambda'(char*&), void (char*&)>>(std::__function::__policy_storage const*, char*&) @ 0x0000000032133534 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000025dab858 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1079: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000032132e08 9. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000032130833 10. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031e9185f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031ca839b 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb4455 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:35.239496 [ 16446 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:35.247566 [ 18772 ] {} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAggThrow.cpp:71: DB::(anonymous namespace)::AggregateFunctionThrow::create(char*) const @ 0x0000000025daa3b9 5. ./build_docker/./src/Interpreters/Aggregator.cpp:811: void DB::Aggregator::createAggregateStates(char*&) const @ 0x0000000031e7dc08 6. ./build_docker/./src/Interpreters/Aggregator.cpp:1087: void std::__function::__policy_invoker::__call_impl[abi:ne190107], FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const::'lambda'(char*&), void (char*&)>>(std::__function::__policy_storage const*, char*&) @ 0x0000000032133534 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000025dab858 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1079: void DB::Aggregator::executeImplBatch, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000032132e08 9. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, char8_t, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000032130833 10. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, FixedHashTableCalculatedSize>, Allocator>, false, false>>(DB::AggregationMethodOneNumber, FixedHashTableCalculatedSize>, Allocator>, false, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031e9185f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031ca839b 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb4455 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 14. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:36.056823 [ 6028 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:36.088763 [ 16889 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:36.118683 [ 17390 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:36.154965 [ 10170 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:36.172881 [ 16323 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:36.438174 [ 18106 ] {5b9a46cf-00af-46bb-b06e-9f84f82a4b27} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=854). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38548) (comment: 00700_decimal_casts.sql) (query 26, line 28) (in query: SELECT '0.000000000000000000000000000000000000001' AS x, toDecimal128(x, 38);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:36.446994 [ 18106 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=854). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:36.619407 [ 17598 ] {1bdcae17-79da-4caf-ada1-58e13d942bbe} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38080) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:36.631116 [ 17598 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:36.974255 [ 16381 ] {08588cc2-d2aa-4e6c-aa18-9dc9895dde8e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38216) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:37.016346 [ 16381 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:37.028954 [ 19194 ] {} TCPHandler: Code: 394. DB::Exception: Query 'e18213e4-f992-4128-bbdb-af6dde6d737e' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033837852 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:14:37.050858 [ 6078 ] {39bba26d-e797-405e-8298-6e9ba841f0b5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38172) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:37.069457 [ 6078 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:37.126064 [ 19618 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:37.545175 [ 19171 ] {0d3af7e2-f7d9-4b8c-9fc4-9f0f2969bad9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38118) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:37.566292 [ 19171 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:37.721716 [ 19618 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:37.733856 [ 16194 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:37.823473 [ 19620 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database no_such_database_could_exist does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:539: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x0000000031ae3afe 5. ./build_docker/./src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x000000003aea11be 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:37.823987 [ 19620 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database no_such_database_could_exist does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:539: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x0000000031ae3afe 5. ./build_docker/./src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x000000003aea11be 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:38.269570 [ 19620 ] {2ecf2ae2-510b-4e56-9fd4-8dab43a388c5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=853). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38322) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:38.308235 [ 19620 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=853). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:14:38.829354 [ 3935 ] {133fe75c-906c-453c-967d-21328aa7b7a1} executeQuery: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03068_analyzer_distributed_join.sql) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_md8b25g6.LINEITEM_shard UUID '12e8de9e-f0cf-4472-b931-0abe6025db9a' (`L_ORDERKEY` UInt64, `L_COMMITDATE` UInt32, `L_RECEIPTDATE` UInt32) ENGINE = MergeTree ORDER BY L_ORDERKEY SETTINGS index_granularity = 49334, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 390358450, compact_parts_max_granules_to_buffer = 8, compact_parts_merge_max_bytes_to_prefetch_part = 10075146, merge_max_block_size = 19891, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1245412760, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10165904075, index_granularity_bytes = 27904390, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 47, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 90488, primary_key_compress_block_size = 65066, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9de917 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000031a82458 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x0000000031a6daad 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x0000000031ac4446 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031ac41ff 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:14:38.855321 [ 3935 ] {133fe75c-906c-453c-967d-21328aa7b7a1} DDLWorker: Query /* ddl_entry=query-0000000002 */ CREATE TABLE test_md8b25g6.LINEITEM_shard UUID '12e8de9e-f0cf-4472-b931-0abe6025db9a' (`L_ORDERKEY` UInt64, `L_COMMITDATE` UInt32, `L_RECEIPTDATE` UInt32) ENGINE = MergeTree ORDER BY L_ORDERKEY SETTINGS index_granularity = 49334, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 390358450, compact_parts_max_granules_to_buffer = 8, compact_parts_merge_max_bytes_to_prefetch_part = 10075146, merge_max_block_size = 19891, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1245412760, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10165904075, index_granularity_bytes = 27904390, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 47, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 90488, primary_key_compress_block_size = 65066, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false wasn't finished successfully: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9de917 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000031a82458 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x0000000031a6daad 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x0000000031ac4446 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031ac41ff 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:38.984897 [ 19621 ] {f6a6efba-1ecc-4d4b-b5ff-b297a4450741} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456789000000000 by scale -6101065173709551616: In scope SELECT toDecimal64(toDecimal64('1234567890', 8), 10). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 4, line 5) (in query: SELECT toDecimal64(toDecimal64('1234567890', 8), 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:39.042344 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456789000000000 by scale -6101065173709551616: In scope SELECT toDecimal64(toDecimal64('1234567890', 8), 10). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:39.162506 [ 16690 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:39.301979 [ 19621 ] {f200149c-ffb0-466b-80f1-0f8f15bfbeee} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456780 by scale -539223888: In scope SELECT toDecimal32(toDecimal32('12345678', 1), 3). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 6, line 8) (in query: SELECT toDecimal32(toDecimal32('12345678', 1), 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42e901 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d2fa 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce82a7e 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce560ef 8. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94e88d 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:39.314130 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying 123456780 by scale -539223888: In scope SELECT toDecimal32(toDecimal32('12345678', 1), 3). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42e901 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d2fa 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce82a7e 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce560ef 8. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94e88d 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:39.373962 [ 19621 ] {e5e97494-8115-487e-9a47-eaeb174f30e2} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying 922337203685477581 by scale -9223372036854775806: In scope SELECT toDecimal64(toDecimal64('92233720368547758.1', 1), 2). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 7, line 10) (in query: SELECT toDecimal64(toDecimal64('92233720368547758.1', 1), 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:39.378188 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying 922337203685477581 by scale -9223372036854775806: In scope SELECT toDecimal64(toDecimal64('92233720368547758.1', 1), 2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:39.449165 [ 19621 ] {d960635c-264e-4543-a247-bbfb92eeba81} executeQuery: Code: 407. DB::Exception: Decimal convert overflow while multiplying -922337203685477581 by scale 9223372036854775806: In scope SELECT toDecimal64(toDecimal64('-92233720368547758.1', 1), 2). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 8, line 11) (in query: SELECT toDecimal64(toDecimal64('-92233720368547758.1', 1), 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:39.474023 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow while multiplying -922337203685477581 by scale 9223372036854775806: In scope SELECT toDecimal64(toDecimal64('-92233720368547758.1', 1), 2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f433573 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x000000002f43d6ba 6. ./src/Functions/FunctionsConversion.h:1760: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced54de 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea702f 8. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f5d9 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:39.534133 [ 16381 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:39.576569 [ 16047 ] {9696139f-650d-4a02-b08f-f9dd3d381392} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38452) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:39.589046 [ 16047 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:39.793094 [ 19621 ] {d98ea48c-cf5e-4f4c-9d47-4037bd5cda8e} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 10, line 14) (in query: SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x000000002f4493d0 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451915 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb2959d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb180d9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c943723 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9736bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c972602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:39.797679 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x000000002f4493d0 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451915 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb2959d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb180d9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c943723 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9736bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c972602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:40.008443 [ 19621 ] {474f1b9a-8ab7-432d-a588-63183fcd11b6} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(-x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 11, line 15) (in query: SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(-x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x000000002f4493d0 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451915 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb2959d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb180d9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c943723 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9736bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c972602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:40.012912 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(-x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x000000002f4493d0 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451915 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb2959d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cb180d9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c943723 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9736bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c972602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:40.034586 [ 17752 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:40.699442 [ 19621 ] {5322969c-062b-4845-bdca-f1cc63b4a68d} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('2147483649', 10) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 15, line 20) (in query: SELECT toDecimal128('2147483649', 10) AS x, toInt32(x), toInt32(-x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, int&) @ 0x000000002f443f39 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450dd5 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb030dd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caf2c99 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c942aa3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96febd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96ee02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:40.715752 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('2147483649', 10) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, int&) @ 0x000000002f443f39 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450dd5 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb030dd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caf2c99 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c942aa3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96febd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96ee02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:40.871071 [ 16390 ] {5f461992-4357-4257-b6f2-3be4aadb26b2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38570) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:40.877993 [ 16390 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:40.909226 [ 16887 ] {e6acc2b8-e565-4143-8dc0-05c616dd68b1} executeQuery: Code: 80. DB::Exception: There was an error on [localhost:9000]: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)). (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03068_analyzer_distributed_join.sql) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_md8b25g6.LINEITEM_shard UUID '12e8de9e-f0cf-4472-b931-0abe6025db9a' ON CLUSTER test_shard_localhost (`L_ORDERKEY` UInt64, `L_COMMITDATE` UInt32, `L_RECEIPTDATE` UInt32) ENGINE = MergeTree ORDER BY L_ORDERKEY SETTINGS index_granularity = 49334, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 390358450, compact_parts_max_granules_to_buffer = 8, compact_parts_merge_max_bytes_to_prefetch_part = 10075146, merge_max_block_size = 19891, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1245412760, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10165904075, index_granularity_bytes = 27904390, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 47, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 90488, primary_key_compress_block_size = 65066, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:14:40.957082 [ 16887 ] {e6acc2b8-e565-4143-8dc0-05c616dd68b1} executeQuery: Code: 80. DB::Exception: There was an error on [localhost:9000]: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)). (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38242) (comment: 03068_analyzer_distributed_join.sql) (query 2, line 5) (in query: CREATE TABLE LINEITEM_shard ON CLUSTER test_shard_localhost (`L_ORDERKEY` UInt64, `L_COMMITDATE` UInt32, `L_RECEIPTDATE` UInt32) ENGINE = MergeTree ORDER BY L_ORDERKEY SETTINGS index_granularity = 49334, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 390358450, compact_parts_max_granules_to_buffer = 8, compact_parts_merge_max_bytes_to_prefetch_part = 10075146, merge_max_block_size = 19891, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1245412760, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10165904075, index_granularity_bytes = 27904390, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 47, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 90488, primary_key_compress_block_size = 65066, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:14:40.982987 [ 19621 ] {b552c706-1497-47cf-8d39-92f32b8bfec4} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('2147483649', 2) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 17, line 22) (in query: SELECT toDecimal64('2147483649', 2) AS x, toInt32(x), toInt32(-x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450d03 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb0261d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caf2959 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c942dd9 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96febd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96ee02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:41.039971 [ 16887 ] {} TCPHandler: Code: 80. DB::Exception: There was an error on [localhost:9000]: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)). (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 14. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.043504 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('2147483649', 2) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450d03 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cb0261d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caf2959 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c942dd9 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96febd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96ee02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:41.172266 [ 19606 ] {8933f9c2-8404-4ad3-9f16-1505fcc223e7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41572) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.188216 [ 18113 ] {a2f0b959-279a-4432-b01f-7134d9a861eb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41590) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.197684 [ 19606 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.285316 [ 18113 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.648996 [ 17752 ] {87188215-23d2-4c74-a898-ccb14be1aace} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41610) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.668090 [ 17752 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.695860 [ 16215 ] {314baed5-aff4-4043-bcf6-90440123bf38} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41616) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.712615 [ 17388 ] {007178db-ef72-411e-a836-063f0ad68add} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1108.258136 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42326) (comment: 02293_http_header_full_summary_without_progress.sh) (in query: SELECT 1 + sleepEachRow(0.00002) FROM numbers(100000) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.741171 [ 17388 ] {007178db-ef72-411e-a836-063f0ad68add} DynamicQueryHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1108.258136 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:41.858927 [ 16215 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.879691 [ 16397 ] {7ca711c9-0043-4f91-a4ad-0d3bbefb6b29} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41618) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:41.886928 [ 16397 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:42.681846 [ 16381 ] {98861ffe-4ae7-459c-b6c7-7e5fdba6bdf9} executeQuery: Code: 344. DB::Exception: OPTIMIZE DEDUPLICATE query is not supported for table tp as it has projections. User should drop all the projections manually before running the query, or consider drop or rebuild option of deduplicate_merge_projection_mode. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38494) (comment: 03206_projection_merge_special_mergetree_ignore.sql) (query 5, line 13) (in query: OPTIMIZE TABLE tp DEDUPLICATE;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1650: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e97e2 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033957419 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:14:42.690726 [ 16381 ] {} TCPHandler: Code: 344. DB::Exception: OPTIMIZE DEDUPLICATE query is not supported for table tp as it has projections. User should drop all the projections manually before running the query, or consider drop or rebuild option of deduplicate_merge_projection_mode. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1650: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e97e2 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033957419 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:14:42.956311 [ 16390 ] {c8b229e3-8a77-4732-853e-30ed8ca31691} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41696) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:42.982025 [ 16390 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:43.343994 [ 19621 ] {0d9cafee-e646-47e0-852a-4cd5d2caaed9} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 32, line 43) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:43.354394 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:43.406424 [ 19621 ] {99f77137-4a2e-4adb-af0e-ebadac5aafd1} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 33, line 44) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:43.410848 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:43.412546 [ 18727 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:43.448798 [ 4528 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.53 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:43.449427 [ 4528 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.53 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:43.453676 [ 16109 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.53 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:43.454167 [ 16109 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.53 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:43.456851 [ 19187 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.49 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:43.457495 [ 19187 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.49 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:43.480906 [ 19621 ] {b0383b38-861b-4648-92fd-6a48aedc2f42} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 34, line 45) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:43.487188 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:43.573414 [ 19621 ] {af051c52-60c5-4d0c-b3db-7b9fa8c4b930} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 35, line 46) (in query: SELECT toDecimal128('-1', 7) AS x, toUInt8(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, char8_t&) @ 0x000000002f4471c6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f512 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d7db6 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1df9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c3c3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:43.589032 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt8(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, char8_t&) @ 0x000000002f4471c6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f512 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d7db6 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1df9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c3c3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:43.696807 [ 19621 ] {f836858f-16d1-4bb3-a93d-7dc539ba1708} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 36, line 48) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f45207a 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4b667 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3a899 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93eb39 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:43.700953 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f45207a 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4b667 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3a899 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93eb39 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:43.781090 [ 19621 ] {beaf418b-846f-4c9a-9321-c9ec6afb05d0} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 37, line 49) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:43.796115 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:43.876151 [ 19621 ] {d3605c9d-fdb0-426f-baa6-a6a754c60156} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 38, line 50) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:43.880523 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:43.951025 [ 19621 ] {27e200ec-3813-4fe1-8fa2-61ae660a7abe} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 39, line 51) (in query: SELECT toDecimal64('-1', 5) AS x, toUInt8(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f443 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d7043 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1ab9 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c6f9 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:43.978812 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt8(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f443 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d7043 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1ab9 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c6f9 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:44.038035 [ 19621 ] {9d214ba5-4c41-4612-9a9a-14a6530a6b88} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 40, line 53) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451e05 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4abac 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3a559 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e84d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:44.055813 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451e05 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4abac 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3a559 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e84d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:44.094953 [ 19621 ] {cb9c6c9d-87d0-4166-bb23-c899c3060f9f} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 41, line 54) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4512e5 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24387 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca14e39 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93dbcd 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:44.107260 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4512e5 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24387 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca14e39 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93dbcd 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:44.151090 [ 19621 ] {4412a4d8-ef5c-4bb8-b2aa-baab4d663891} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 42, line 55) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450368 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9fefbd 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9ef8d9 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf4d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:44.168812 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450368 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9fefbd 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9ef8d9 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf4d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:44.214607 [ 16381 ] {f57d8f5d-4ff6-4e57-892b-65699c08b65a::all_1_2_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.53 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a4cd316 31. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e73d0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:44.248972 [ 19621 ] {8dd71b33-3be0-4227-b2f6-95ee0e2516bc} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 43, line 56) (in query: SELECT toDecimal32('-1', 3) AS x, toUInt8(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f1a7 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d62a3 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1779 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c40d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:44.253155 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt8(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f44f1a7 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt8, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9d62a3 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9c1779 7. ./src/Core/callOnTypeIndex.h:270: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93c40d 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c953ebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:44.266900 [ 16381 ] {e264318c-03d6-48cc-8bc7-ba52e52adc99} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.53 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38494) (comment: 03206_projection_merge_special_mergetree_ignore.sql) (query 6, line 15) (in query: OPTIMIZE TABLE tp FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a4cd316 31. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e73d0 2025.11.13 09:14:44.274988 [ 16381 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.53 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a4cd316 31. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e73d0 2025.11.13 09:14:44.725275 [ 19621 ] {5fc917ba-754a-4a74-a181-a773d6b4ed4c} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 0) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 45, line 59) (in query: SELECT toDecimal128('18446744073709551616', 0) AS x, toUInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:44.729524 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 0) AS x, toUInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:44.992771 [ 19621 ] {d8e2bfec-2711-457d-92ab-dec96121067e} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 8) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 47, line 61) (in query: SELECT toDecimal128('18446744073709551616', 8) AS x, toUInt64(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:44.998045 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 8) AS x, toUInt64(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x000000002f44a446 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f452155 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca4c11d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3abd9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e803 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:45.223340 [ 19621 ] {b7d13b63-f974-4ee1-8a58-d2cdc3095e49} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 49, line 64) (in query: SELECT toDecimal128('4294967296', 0) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:45.229615 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:45.263479 [ 10692 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:45.355167 [ 4550 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:45.394206 [ 16886 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:45.408643 [ 19187 ] {c97facae-b265-4bd5-893f-1719cef1e3bf} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41992) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:45.416399 [ 19187 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:45.436613 [ 18389 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:45.510503 [ 19621 ] {9f84f27c-7aa7-4433-bbd6-643b77743cd8} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 10) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 51, line 66) (in query: SELECT toDecimal128('4294967296', 10) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:45.514998 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 10) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x000000002f445034 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451655 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca258fd 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca154b9 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93db83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:45.705980 [ 19621 ] {472f3841-6e61-4db8-a0f7-5097c38c873a} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 53, line 68) (in query: SELECT toDecimal64('4294967296', 0) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:45.726796 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:46.009606 [ 18376 ] {7a3e6922-c66e-401b-92f4-cd6a3c477774} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.53 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37852) (comment: 03237_insert_sparse_columns_mem.sh) (query 1, line 1) (in query: INSERT INTO t_reference SELECT * FROM file('test_data_sparse_test_weof1sxc.json', JSONEachRow)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/StorageLog.cpp:366: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x0000000038f6935c 14. ./contrib/llvm-project/libcxx/include/__utility/pair.h:478: std::unique_ptr, void*>, std::__tree_node_destructor, void*>>>> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__construct_node, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x0000000038f68c08 15. ./contrib/llvm-project/libcxx/include/__tree:1779: std::pair, std::__tree_node, void*>*, long>>, bool> std::map, std::allocator>>::try_emplace[abi:ne190107] const&, String const&, unsigned long, std::shared_ptr&, unsigned long const&>(String const&, std::shared_ptr const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&) @ 0x0000000038f67d83 16. ./build_docker/./src/Storages/StorageLog.cpp:500: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000038f5a1c3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/StorageLog.cpp:487: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x0000000038f3cb45 20. ./build_docker/./src/Storages/StorageLog.cpp:420: DB::LogSink::consume(DB::Chunk&) @ 0x0000000038f3c493 21. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 29. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:14:46.020545 [ 19621 ] {4955ba7c-6555-49dd-80df-76461170c967} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 4) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 55, line 70) (in query: SELECT toDecimal64('4294967296', 4) AS x, toUInt32(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:46.033959 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 4) AS x, toUInt32(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f451579 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca24e3d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca15179 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e003 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:46.339341 [ 19621 ] {f43e0ce3-3bda-442c-b1e7-e9e73e653a41} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 57, line 73) (in query: SELECT toDecimal128('65536', 0) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:46.372673 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:46.623879 [ 19621 ] {523b666e-ff0e-4775-b3f5-12d9191c3ef0} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 10) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 59, line 75) (in query: SELECT toDecimal128('65536', 10) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:46.645696 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 10) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x000000002f442ec6 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f4506d4 6. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca0053d 7. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9eff59 8. ./src/Core/callOnTypeIndex.h:272: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93cf03 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:46.932472 [ 19621 ] {820f80f8-fa88-4bff-a2ef-d3b99ca46995} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 61, line 77) (in query: SELECT toDecimal64('65536', 0) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:46.960752 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:47.223875 [ 19621 ] {bb66212d-746a-429c-abb7-80d957aa55f3} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 4) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 63, line 79) (in query: SELECT toDecimal64('65536', 4) AS x, toUInt16(x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:47.318786 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 4) AS x, toUInt16(x). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x000000002f450603 5. ./src/Functions/FunctionsConversion.h:1762: COW::immutable_ptr DB::detail::ConvertImpl>, DB::DataTypeNumber, DB::detail::NameToUInt16, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002c9ffa7d 6. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator()>, DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002c9efc19 7. ./src/Core/callOnTypeIndex.h:271: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93d239 8. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9576bd 9. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt16, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c956602 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:47.319230 [ 16200 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:47.335573 [ 17731 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:47.658031 [ 18700 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:47.694450 [ 18376 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.53 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/StorageLog.cpp:366: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x0000000038f6935c 14. ./contrib/llvm-project/libcxx/include/__utility/pair.h:478: std::unique_ptr, void*>, std::__tree_node_destructor, void*>>>> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__construct_node, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x0000000038f68c08 15. ./contrib/llvm-project/libcxx/include/__tree:1779: std::pair, std::__tree_node, void*>*, long>>, bool> std::map, std::allocator>>::try_emplace[abi:ne190107] const&, String const&, unsigned long, std::shared_ptr&, unsigned long const&>(String const&, std::shared_ptr const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&) @ 0x0000000038f67d83 16. ./build_docker/./src/Storages/StorageLog.cpp:500: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000038f5a1c3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/StorageLog.cpp:487: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x0000000038f3cb45 20. ./build_docker/./src/Storages/StorageLog.cpp:420: DB::LogSink::consume(DB::Chunk&) @ 0x0000000038f3c493 21. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 29. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:47.760479 [ 19621 ] {0588d7aa-d78d-4804-a3ce-1d184060f17c} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 67, line 84) (in query: SELECT toInt64('2147483649') AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42eff7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c10e 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce764d8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5152f 8. ./src/Core/callOnTypeIndex.h:262: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ee19 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:47.769804 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42eff7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c10e 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce764d8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5152f 8. ./src/Core/callOnTypeIndex.h:262: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ee19 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:47.821649 [ 19621 ] {f7de02f4-c223-41ea-8f7d-dbd0bdb53187} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: -2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('-2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 68, line 85) (in query: SELECT toInt64('-2147483649') AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42eff7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c10e 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce764d8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5152f 8. ./src/Core/callOnTypeIndex.h:262: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ee19 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:47.860163 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: -2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toInt64('-2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42eff7 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c10e 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce764d8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5152f 8. ./src/Core/callOnTypeIndex.h:262: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ee19 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:47.916152 [ 19621 ] {4cb78f72-d8f8-49f8-be02-7dcc08fe3458} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toUInt64('2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 69, line 86) (in query: SELECT toUInt64('2147483649') AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42fef3 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c224 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce69ed8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce4c96f 8. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ed83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:47.923833 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 2147483649 is not in range (-2147483648, 2147483647): In scope SELECT toUInt64('2147483649') AS x, toDecimal32(x, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f42fef3 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45c224 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce69ed8 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce4c96f 8. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94ed83 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:47.974255 [ 18824 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:48.094104 [ 17226 ] {8bcea97d-a576-43a3-92f4-0623f8d718c2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52424) (comment: 03237_insert_sparse_columns_mem.sh) (in query: DROP DATABASE IF EXISTS test_weof1sxc SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:48.098147 [ 17226 ] {8bcea97d-a576-43a3-92f4-0623f8d718c2} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:48.246958 [ 19621 ] {91c0bd03-94fd-4a71-9b2a-b27d3e139267} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 9223372036854775809 is not in range (-9223372036854775808, 9223372036854775807): In scope SELECT toUInt64('9223372036854775809') AS x, toDecimal64(x, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 71, line 89) (in query: SELECT toUInt64('9223372036854775809') AS x, toDecimal64(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f434110 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45d264 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ceba301 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce9cc0f 8. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f7e3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:48.323981 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 9223372036854775809 is not in range (-9223372036854775808, 9223372036854775807): In scope SELECT toUInt64('9223372036854775809') AS x, toDecimal64(x, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x000000002f434110 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45d264 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ceba301 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce9cc0f 8. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f7e3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:48.374075 [ 18721 ] {e7738c11-e0ca-4a68-99b3-795ee816406f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03250_ephemeral_comment.sql) (in query: /* ddl_entry=query-0000000003 */ TRUNCATE TABLE IF EXISTS test_60bk7be2.test), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:48.407631 [ 19621 ] {19ef6780-decf-4695-8e1a-01362fbb3901} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal32(0, rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 72, line 91) (in query: SELECT toDecimal32(0, rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9adcbf 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ce49cfd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9ace1c 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9ad5fe 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:48.427510 [ 19621 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal32(0, rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9adcbf 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ce49cfd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9ace1c 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9ad5fe 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:48.480322 [ 18721 ] {e7738c11-e0ca-4a68-99b3-795ee816406f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42236) (comment: 03250_ephemeral_comment.sql) (query 3, line 11) (in query: drop table if exists test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:48.487330 [ 18721 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a69fdf 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:14:48.515554 [ 19621 ] {74085dba-a472-4749-9bac-f21556c45c44} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal64(0, rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 73, line 92) (in query: SELECT toDecimal64(0, rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9b179f 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ce99f9d 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9b08fc 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9b10de 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:48.526196 [ 19621 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal64(0, rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9b179f 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ce99f9d 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9b08fc 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9b10de 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:48.576302 [ 19621 ] {0bc7f1b8-ac3d-4211-84d9-4fc2d4d8699a} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal128(0, rowNumberInBlock()). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 74, line 93) (in query: SELECT toDecimal128(0, rowNumberInBlock());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9b527f 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ceea8bd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9b43dc 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9b4bbe 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:48.596281 [ 19621 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: UInt64: In scope SELECT toDecimal128(0, rowNumberInBlock()). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. ./src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x000000002c9b527f 7. ./src/Functions/FunctionsConversion.h:2196: std::shared_ptr std::__function::__policy_invoker (std::vector> const&)>::__call_impl[abi:ne190107]>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const::'lambda'(auto const&), std::shared_ptr (std::vector> const&)>>(std::__function::__policy_storage const*, std::vector> const&) @ 0x000000002ceea8bd 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c9b43dc 9. ./src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x000000002c9b4bbe 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:14:48.734559 [ 19621 ] {d742b26d-6674-44e1-b770-e729276f2dc2} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal32(1 / 0, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 75, line 95) (in query: SELECT toDecimal32(1/0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:48.739346 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal32(1 / 0, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:48.785861 [ 19621 ] {9518b2b7-b021-4fd9-aab9-de7c1161b3cc} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal64(1 / 0, 1). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 76, line 96) (in query: SELECT toDecimal64(1/0, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:48.798708 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal64(1 / 0, 1). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:48.799517 [ 19172 ] {b1fdf912-95ce-4ef2-a18b-8a0f6e1f6649} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52456) (comment: 03250_ephemeral_comment.sql) (in query: DROP DATABASE IF EXISTS test_60bk7be2 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:48.810481 [ 19172 ] {b1fdf912-95ce-4ef2-a18b-8a0f6e1f6649} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:48.856682 [ 19621 ] {ae8750c6-65b1-4466-ab99-9ed55d685032} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal128(0 / 0, 2). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 77, line 97) (in query: SELECT toDecimal128(0/0, 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:48.863709 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT toDecimal128(0 / 0, 2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:48.917237 [ 19621 ] {a4a64362-1122-4b51-bbfd-76377cd78622} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(9, 0)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 78, line 98) (in query: SELECT CAST(1/0, 'Decimal(9, 0)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c69d1b8 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c677119 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c66c45f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c66b5a4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:48.921853 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(9, 0)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c69d1b8 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c677119 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c66c45f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c66b5a4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:48.950631 [ 19621 ] {3c1ee216-f385-4d8a-a008-8ea8aaca8c94} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(18, 1)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 79, line 99) (in query: SELECT CAST(1/0, 'Decimal(18, 1)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c6e15e1 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c6baf79 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6b02bf 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6af404 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:48.955216 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(18, 1)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c6e15e1 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c6baf79 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6b02bf 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6af404 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:48.963152 [ 18131 ] {61de1209-3347-44a9-8a6c-f5ad9d8180af} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:270edce7-5723-4ba5-bbd2-821afaa0074b'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52466) (comment: 01291_geo_types.sql) (in query: CREATE DATABASE IF NOT EXISTS test_gm4cdufi ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:48.967252 [ 18131 ] {61de1209-3347-44a9-8a6c-f5ad9d8180af} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:270edce7-5723-4ba5-bbd2-821afaa0074b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:49.011667 [ 19621 ] {224e26e4-12da-4735-8ccb-619c76cc2d79} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(38, 2)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 80, line 100) (in query: SELECT CAST(1/0, 'Decimal(38, 2)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c725a4d 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>>(T const&) const @ 0x000000002c6ff639 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6f497f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6f3ac4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:49.020183 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(1 / 0, 'Decimal(38, 2)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c725a4d 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>>(T const&) const @ 0x000000002c6ff639 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6f497f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6f3ac4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:49.034645 [ 18131 ] {7ed90b81-7ded-4c71-87c2-ce4b5920aa2e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:edfef320-a529-4d2e-8244-a5a970e03e85'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52478) (comment: 03248_with_fill_string_crash.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zma1ptep ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.045223 [ 18131 ] {7ed90b81-7ded-4c71-87c2-ce4b5920aa2e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:edfef320-a529-4d2e-8244-a5a970e03e85'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:49.082060 [ 19621 ] {42d7ba16-b0a2-456c-81d8-42b7ad301701} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(9, 3)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 81, line 101) (in query: SELECT CAST(0/0, 'Decimal(9, 3)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c69d1b8 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c677119 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c66c45f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c66b5a4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:49.114600 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(9, 3)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f4575d1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c69d1b8 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c677119 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c66c45f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c66b5a4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:49.195238 [ 16354 ] {37287475-6897-49d9-bcde-ccf73049341e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:ef8ee1b7-74ad-40bd-8c21-f72005c52e7d'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52490) (comment: 00032_fixed_string_to_string.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3ys3oijd ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.199497 [ 16354 ] {37287475-6897-49d9-bcde-ccf73049341e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:ef8ee1b7-74ad-40bd-8c21-f72005c52e7d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:49.201818 [ 19621 ] {9c9152d2-cde0-4472-bfe9-f40f7b0918a8} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(18, 4)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 82, line 102) (in query: SELECT CAST(0/0, 'Decimal(18, 4)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c6e15e1 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c6baf79 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6b02bf 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6af404 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:49.206698 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(18, 4)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457ea1 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c6e15e1 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>(T const&) const @ 0x000000002c6baf79 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6b02bf 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6af404 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:49.240158 [ 19172 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.284593 [ 19621 ] {543f15bb-4ef3-4d1d-94a3-f7e6ee11315f} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(38, 5)'). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 83, line 103) (in query: SELECT CAST(0/0, 'Decimal(38, 5)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c725a4d 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>>(T const&) const @ 0x000000002c6ff639 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6f497f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6f3ac4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:49.310459 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Cannot convert infinity or NaN to decimal: In scope SELECT CAST(0 / 0, 'Decimal(38, 5)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458b5e 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002c725a4d 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator(), DB::DataTypeDecimal>>>>(T const&) const @ 0x000000002c6ff639 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6f497f 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6f3ac4 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:14:49.327547 [ 16354 ] {521318d0-2dd8-44af-a023-2ea529c79d41} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:a1819847-dbb3-418b-9ae7-6827294d0b09'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52498) (comment: 01902_self_aliases_in_columns.sql) (in query: CREATE DATABASE IF NOT EXISTS test_z3wux07e ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.349226 [ 16354 ] {521318d0-2dd8-44af-a023-2ea529c79d41} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:a1819847-dbb3-418b-9ae7-6827294d0b09'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:49.383565 [ 19621 ] {3b459916-7366-4a18-9df3-22dbcf8ad432} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(10000.1, 6). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 84, line 105) (in query: select toDecimal32(10000.1, 6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.410031 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(10000.1, 6). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.436731 [ 17228 ] {3265e0a8-044d-4175-bacc-684b291866eb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42442) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.464752 [ 17228 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.476321 [ 19621 ] {d5a58b89-d830-4ccb-b3fc-5460a9ec1994} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(10000.1, 18). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 85, line 106) (in query: select toDecimal64(10000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.494374 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(10000.1, 18). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.548154 [ 19621 ] {cc1ddd41-f247-4637-872e-73f9713542d4} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1e21, 18). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 86, line 107) (in query: select toDecimal128(1000000000000000000000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.570207 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1e21, 18). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.611258 [ 16703 ] {0b523d6f-d28d-4349-be3e-f87040d0e1da} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:243b6266-6ffe-46b5-8fc3-57930b6b9950'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52510) (comment: 01901_in_literal_shard_prune.sql) (in query: CREATE DATABASE IF NOT EXISTS test_sc08gklz ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.615889 [ 16703 ] {0b523d6f-d28d-4349-be3e-f87040d0e1da} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:243b6266-6ffe-46b5-8fc3-57930b6b9950'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:49.649493 [ 19621 ] {1a78b4cd-c460-477b-aa35-cac3cf8bf072} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-10000.1, 6). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 87, line 109) (in query: select toDecimal32(-10000.1, 6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.654845 [ 16207 ] {6e3de760-12d8-4221-a873-3c81d11f9450} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42358) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.662019 [ 16207 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.678678 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-10000.1, 6). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.772846 [ 2996 ] {0eb0eac1-50bb-4ca0-9b41-8e889d6b6655} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42456) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.779202 [ 6070 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.786166 [ 5803 ] {e20ea357-f446-4a64-bf4e-90f339e5ab28} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42416) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.786757 [ 2996 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.810124 [ 17226 ] {21701854-8095-46b6-a789-0c7a76c2c503} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42492) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.812767 [ 19621 ] {bd923a22-d660-446f-ac88-490670abddd1} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-10000.1, 18). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 88, line 110) (in query: select toDecimal64(-10000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.817369 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-10000.1, 18). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.821169 [ 17226 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.839636 [ 5803 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:49.865718 [ 19621 ] {e1296ed8-ced1-46e9-9588-25f1436110f1} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1e21, 18). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 89, line 111) (in query: select toDecimal128(-1000000000000000000000.1, 18);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.870930 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1e21, 18). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.921683 [ 19621 ] {741ed308-ea3e-419b-99d8-91a21a28bc3a} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(2147483647. + 1., 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 90, line 113) (in query: select toDecimal32(2147483647.0 + 1.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:49.928846 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(2147483647. + 1., 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.010878 [ 19621 ] {418eae22-336c-4b68-bc28-cf2c827af959} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(9223372036854776000., 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 91, line 114) (in query: select toDecimal64(9223372036854775807.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.015622 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(9223372036854776000., 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.076459 [ 18149 ] {52c639b6-e637-49f1-9428-36a1ce41a5b2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:e67f5192-3a83-4cc9-b858-a5654ddaff3f'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52512) (comment: 00839_bitmask_negative.sql) (in query: CREATE DATABASE IF NOT EXISTS test_4u8noqek ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:50.080555 [ 18149 ] {52c639b6-e637-49f1-9428-36a1ce41a5b2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:e67f5192-3a83-4cc9-b858-a5654ddaff3f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:50.086561 [ 19621 ] {efa89b8e-df7d-4802-9cfa-fb7d779f4348} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1.7014118346046923e38, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 92, line 115) (in query: select toDecimal128(170141183460469231731687303715884105729.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.087082 [ 16691 ] {44eb75c6-b775-4ab8-87e5-fb33da6d1bec} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42520) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:50.091335 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(1.7014118346046923e38, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.112658 [ 16691 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:50.231741 [ 19621 ] {8fbad402-290c-4d8a-9cd0-70b4a3362c05} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-2147483647. - 1., 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 93, line 117) (in query: select toDecimal32(-2147483647.0 - 1.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.246720 [ 16920 ] {9b4c4200-bfd9-4cb2-bac9-633677fe5b13} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:36075e78-0bb9-4655-9608-fd6a8b378c46'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52514) (comment: 01119_session_log.sh) (in query: CREATE DATABASE IF NOT EXISTS test_v7ag4hul ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:50.251741 [ 16920 ] {9b4c4200-bfd9-4cb2-bac9-633677fe5b13} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:36075e78-0bb9-4655-9608-fd6a8b378c46'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:50.258932 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal32(-2147483647. - 1., 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f45771b 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45ca55 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ce80978 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ce5544f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94eca3 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9af33d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9ae282 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.319253 [ 19621 ] {ff795ae3-01dd-47d2-a394-a3d0c8323f08} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-9223372036854776000., 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 94, line 118) (in query: select toDecimal64(-9223372036854775807.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.326011 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal64(-9223372036854776000., 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f457fee 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x000000002f45dab5 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::NameToDecimal64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002ced11c1 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cea56ef 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c94f703 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b2e1d 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b1d62 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.339061 [ 16352 ] {d51f5d2c-85ca-47a6-8dd1-48644c929c8a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:ccadc76e-9d0f-4213-b8ae-ca0d0ccc6911'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52518) (comment: 02441_alter_delete_and_drop_column.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2u1s0x1z ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:50.342946 [ 16352 ] {d51f5d2c-85ca-47a6-8dd1-48644c929c8a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:ccadc76e-9d0f-4213-b8ae-ca0d0ccc6911'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:50.388931 [ 16200 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6f4f 9. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:50.404501 [ 19621 ] {cfc28c24-c07e-4c95-8e6c-466e1687b6bc} executeQuery: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1.7014118346046923e38, 0). (DECIMAL_OVERFLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38326) (comment: 00700_decimal_casts_2.sql) (query 95, line 119) (in query: select toDecimal128(-170141183460469231731687303715884105729.0, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.409142 [ 19621 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow. Float is out of Decimal range: In scope SELECT toDecimal128(-1.7014118346046923e38, 0). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x000000002f458cae 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x000000002f45eedc 6. ./src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeDecimal>>, DB::detail::NameToDecimal128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x000000002cf223cd 7. ./src/Functions/FunctionsConversion.h:2409: bool DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeDecimal>>>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cef600f 8. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType>>, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c950163 9. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b68fd 10. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9b5842 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:14:50.479047 [ 16920 ] {a2f6e22a-dea8-4071-aeec-bc3b3776fed5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:7a694818-9b09-4d95-9483-56126066b314'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52524) (comment: 03109_ast_too_big.sql) (in query: CREATE DATABASE IF NOT EXISTS test_7uwxf69v ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:50.483458 [ 16920 ] {a2f6e22a-dea8-4071-aeec-bc3b3776fed5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:7a694818-9b09-4d95-9483-56126066b314'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:50.664510 [ 16355 ] {09ad5188-56ba-4978-bd61-547ac8df6e0b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:772901af-51a4-40de-98d8-bcd38233be4b'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38162) (comment: 02764_parallel_replicas_plain_merge_tree.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9u3gy83q ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:50.668660 [ 16355 ] {09ad5188-56ba-4978-bd61-547ac8df6e0b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:772901af-51a4-40de-98d8-bcd38233be4b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:50.795311 [ 18724 ] {ec254c81-f011-4d6d-a0a1-3784a4ca8014} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:d358926b-af60-449d-94e5-2215bf04f1a4'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38164) (comment: 03444_distributed_wo_hedged_requests.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ii1dfhlr ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:50.800330 [ 18724 ] {ec254c81-f011-4d6d-a0a1-3784a4ca8014} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:d358926b-af60-449d-94e5-2215bf04f1a4'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:51.231644 [ 16889 ] {2e3dc3f4-7f7d-4a95-92f2-64a50295459e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:8089eb43-dbe0-4873-9265-ced74162e094'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38176) (comment: 02725_sleep_max_time.sql) (in query: CREATE DATABASE IF NOT EXISTS test_fgdiajnd ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:51.239634 [ 16889 ] {2e3dc3f4-7f7d-4a95-92f2-64a50295459e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:8089eb43-dbe0-4873-9265-ced74162e094'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:51.259459 [ 16195 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:51.620678 [ 16920 ] {71173852-5e4f-4ec9-8dcc-bb473b8ea413} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:84cfd717-468d-4d34-abb4-034e487975c1'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38190) (comment: 00525_aggregate_functions_of_nullable_that_return_non_nullable.sql) (in query: CREATE DATABASE IF NOT EXISTS test_xjb2c6f2 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:51.627969 [ 16920 ] {71173852-5e4f-4ec9-8dcc-bb473b8ea413} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:84cfd717-468d-4d34-abb4-034e487975c1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:51.641601 [ 16323 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:51.671721 [ 6028 ] {d3db0253-1380-4909-9bd6-3dfbdfe06f02} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55472) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:51.687502 [ 6028 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:51.905438 [ 18724 ] {870df54d-6d11-41f2-91aa-92e6cf372915} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55484) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:51.921897 [ 18149 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:51.949672 [ 16195 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:52.002403 [ 16889 ] {22df8ae4-2b29-481e-a6f1-f5c6efb8960f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:f59351cd-df2d-4ab7-8b7f-af4716402415'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38196) (comment: 02899_restore_parts_replicated_merge_tree.sh) (in query: CREATE DATABASE IF NOT EXISTS test_xijtjiec ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:52.006997 [ 16889 ] {22df8ae4-2b29-481e-a6f1-f5c6efb8960f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:f59351cd-df2d-4ab7-8b7f-af4716402415'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:52.031431 [ 18724 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:52.092256 [ 10170 ] {599e42a9-a6ba-4b18-893d-fdc6a2a070be} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55516) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:52.105399 [ 10170 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:52.225700 [ 19171 ] {8d0b8937-77e8-477b-b024-7a1667787dcd} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:5d891047-a94d-49f7-942e-40f27cde88ad'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38222) (comment: 02480_interval_casting_and_subquery.sql) (in query: CREATE DATABASE IF NOT EXISTS test_a2tmflej ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:52.229579 [ 19171 ] {8d0b8937-77e8-477b-b024-7a1667787dcd} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:5d891047-a94d-49f7-942e-40f27cde88ad'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:52.335463 [ 19618 ] {0c1028fc-b1b3-400f-adcc-0d10cff47584} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:f338f328-345d-43e6-bda8-d264df881584'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38224) (comment: 01425_default_value_of_type_name.sql) (in query: CREATE DATABASE IF NOT EXISTS test_of7vjovl ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:52.339625 [ 19618 ] {0c1028fc-b1b3-400f-adcc-0d10cff47584} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:f338f328-345d-43e6-bda8-d264df881584'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:52.426106 [ 16054 ] {52a86fd3-29ff-4c91-8a81-224ee3b72476} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:2d7d7994-8b5c-4d52-bb04-fdc51605da25'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38252) (comment: 01942_snowflakeIDToDateTime.sql) (in query: CREATE DATABASE IF NOT EXISTS test_w6i6afwf ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:52.430856 [ 16054 ] {52a86fd3-29ff-4c91-8a81-224ee3b72476} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:2d7d7994-8b5c-4d52-bb04-fdc51605da25'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:52.601749 [ 19171 ] {93be4116-58e1-467e-b781-4bfd5430cfd6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:2304d6b9-c112-4c07-8526-c09f0ff0035c'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38264) (comment: 01010_pmj_on_disk.sql) (in query: CREATE DATABASE IF NOT EXISTS test_4fnfwl0g ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:52.618909 [ 19171 ] {93be4116-58e1-467e-b781-4bfd5430cfd6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:2304d6b9-c112-4c07-8526-c09f0ff0035c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:52.749338 [ 19171 ] {35e08d60-c8a8-4957-9fd0-0a2f3c6c7acb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:4232f22b-9592-43c5-8c40-94c97f453382'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38266) (comment: 01013_hex_float.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2dot55i8 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:52.753479 [ 19171 ] {35e08d60-c8a8-4957-9fd0-0a2f3c6c7acb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:4232f22b-9592-43c5-8c40-94c97f453382'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.097378 [ 16054 ] {2ac4be04-897f-4b56-9da0-7624afb9c789} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:b509c24b-4e1e-4845-b6a0-9c702c92fc4b'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38272) (comment: 01526_complex_key_dict_direct_layout.sql) (in query: CREATE DATABASE IF NOT EXISTS test_mp4m6tfv ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:53.112146 [ 16054 ] {2ac4be04-897f-4b56-9da0-7624afb9c789} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:b509c24b-4e1e-4845-b6a0-9c702c92fc4b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.204953 [ 18106 ] {7b3b98eb-51ff-4561-9779-52daf4887bd2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:155a8920-a066-4155-b887-8af7d8cc09f7'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38280) (comment: 02314_csv_tsv_skip_first_lines.sql) (in query: CREATE DATABASE IF NOT EXISTS test_t0pxrcw6 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:53.288632 [ 18106 ] {7b3b98eb-51ff-4561-9779-52daf4887bd2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:155a8920-a066-4155-b887-8af7d8cc09f7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.601322 [ 19243 ] {8b01ed49-d077-4825-bfcc-ddb2a85e01fe} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:e69d5218-c004-42a7-94a6-1ec078a9ccc2'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38296) (comment: 02494_query_cache_normalize_ast.sql) (in query: CREATE DATABASE IF NOT EXISTS test_8j6064e2 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:53.791143 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.822379 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.845926 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.846613 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.861398 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.861931 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.872193 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.872728 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.929210 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.929767 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.933251 [ 19243 ] {8b01ed49-d077-4825-bfcc-ddb2a85e01fe} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:e69d5218-c004-42a7-94a6-1ec078a9ccc2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.937087 [ 16054 ] {ec8f9a75-abb3-4f42-8a46-66dba6756d14} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55672) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:53.937948 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.938470 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.945647 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.946178 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:53.962459 [ 16054 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:53.960446 [ 19171 ] {43272722-925b-40f8-9641-5c11555f7cbd} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55694) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:53.969464 [ 16352 ] {8cdb25ec-8f33-47d1-98f2-258cc14ca12b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55656) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:53.992178 [ 19171 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:54.017815 [ 16352 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:54.036803 [ 17383 ] {cf755dfb-d286-4fd4-b740-0ba544e17146} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55670) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:54.067684 [ 17383 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:54.069447 [ 17598 ] {6ee6c5d7-ff2e-47dc-91d1-16732f6e8e66} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55636) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:54.089311 [ 17598 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:54.238169 [ 16446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:54.259988 [ 6078 ] {f30bbd13-f4cc-4015-ab34-121837afab37} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55704) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:54.268233 [ 6078 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:54.829185 [ 19618 ] {25c7609a-a564-4bae-8a68-10e9ec6f5d26} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55698) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c52d9 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:14:54.857019 [ 19618 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c52d9 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.155977 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.24 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:55.302948 [ 19194 ] {589b26be-61e3-41cc-a5f7-7afbb8c9fafb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:14e36486-e175-4067-a426-e3adee1cbaf0'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38350) (comment: 02522_avro_complicate_schema.sh) (in query: CREATE DATABASE IF NOT EXISTS test_sdjjmwzb ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.307969 [ 19194 ] {589b26be-61e3-41cc-a5f7-7afbb8c9fafb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:14e36486-e175-4067-a426-e3adee1cbaf0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:55.415166 [ 19618 ] {3fe877e7-f8ae-4987-8f8f-04f21619cafe} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:83753767-7c49-44af-b094-1cca160a5038'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38362) (comment: 02293_formats_json_columns.sh) (in query: CREATE DATABASE IF NOT EXISTS test_pqe21lpm ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.440848 [ 19618 ] {3fe877e7-f8ae-4987-8f8f-04f21619cafe} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:83753767-7c49-44af-b094-1cca160a5038'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:55.547109 [ 19194 ] {d94a8a54-be63-4b0b-97f9-18ddb63e9f30} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:d7c98090-e3a2-4482-9f59-a2836f7309fa'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38368) (comment: 02895_npy_output_format.sh) (in query: CREATE DATABASE IF NOT EXISTS test_8h9cu5en ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.560620 [ 19194 ] {d94a8a54-be63-4b0b-97f9-18ddb63e9f30} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:d7c98090-e3a2-4482-9f59-a2836f7309fa'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:55.699195 [ 18771 ] {117e1ab2-290f-4015-8523-d6f371fa04d0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:639a1d8e-f224-468b-8d5a-886422a31483'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38378) (comment: 00083_array_filter.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lhtdbyb9 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.703266 [ 18771 ] {117e1ab2-290f-4015-8523-d6f371fa04d0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:639a1d8e-f224-468b-8d5a-886422a31483'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:55.775326 [ 17752 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.795341 [ 19499 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.846044 [ 19194 ] {dcb439c5-8bb8-4b76-86c2-a7a15cc81a10} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:57c745df-24e5-4deb-a1a2-8dffdc0b0220'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38388) (comment: 01035_concurrent_move_partition_from_table_zookeeper.sh) (in query: CREATE DATABASE IF NOT EXISTS test_6vslx7ga ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.850342 [ 19194 ] {dcb439c5-8bb8-4b76-86c2-a7a15cc81a10} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:57c745df-24e5-4deb-a1a2-8dffdc0b0220'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:55.875147 [ 16397 ] {5c8d9f10-0af0-4ddf-8198-052ef26886b0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55888) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.894006 [ 19619 ] {bf9b4f8e-867d-4e1c-a0bb-fd8155f6ac02} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55912) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.901978 [ 16390 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.924522 [ 16397 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.952877 [ 18113 ] {392a11c2-978e-4ae7-8f96-1519559c629d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:5c0df5f3-3a9d-46dc-b2e2-6b84d9280d93'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38404) (comment: 02314_avro_null_as_default.sh) (in query: CREATE DATABASE IF NOT EXISTS test_0recnhnb ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.964684 [ 19619 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:55.968028 [ 18113 ] {392a11c2-978e-4ae7-8f96-1519559c629d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:5c0df5f3-3a9d-46dc-b2e2-6b84d9280d93'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:56.020637 [ 16690 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:56.037691 [ 16390 ] {b5da73b7-26ec-4c02-a5c7-3722db2ca7f7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:789da2c1-4ed4-4cee-a025-afdbca0cff8f'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38430) (comment: 01161_all_system_tables.sh) (in query: CREATE DATABASE IF NOT EXISTS test_f1z1clwi ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:56.041574 [ 16390 ] {b5da73b7-26ec-4c02-a5c7-3722db2ca7f7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:789da2c1-4ed4-4cee-a025-afdbca0cff8f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:56.197493 [ 16196 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:56.236626 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 7 entries up to offset 882: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:56.269888 [ 18113 ] {3b059e51-ec8e-44ac-9d72-03b2c74b3828} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:7dd44332-3bab-4922-9780-e83ccfc3d73c'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38436) (comment: 02494_query_cache_eligible_queries.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wt5c06vk ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:56.274358 [ 18113 ] {3b059e51-ec8e-44ac-9d72-03b2c74b3828} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:7dd44332-3bab-4922-9780-e83ccfc3d73c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:56.559131 [ 19194 ] {d07a75d7-6840-4593-81bf-17a03576e92f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:ea8b1407-208f-46a0-ab71-d27bbdcbd59a'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38448) (comment: 02977_csv_format_support_tuple.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nvusoaku ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:56.584964 [ 19194 ] {d07a75d7-6840-4593-81bf-17a03576e92f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:ea8b1407-208f-46a0-ab71-d27bbdcbd59a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:56.686060 [ 19194 ] {10256e98-b05a-46ac-8cbf-55d585ec23c4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:995e5105-a314-4270-849d-1c953073a746'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38468) (comment: 02494_query_cache_tag.sql) (in query: CREATE DATABASE IF NOT EXISTS test_j0huw7bs ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:56.696112 [ 19194 ] {10256e98-b05a-46ac-8cbf-55d585ec23c4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:995e5105-a314-4270-849d-1c953073a746'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:56.819896 [ 19194 ] {b4b58a4e-caf0-4957-9a58-40d68a34effb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:787e9680-75ba-4d74-986b-a1f07bb914cd'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38474) (comment: 02101_sql_user_defined_functions_create_or_replace.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pkf5si6e ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:56.823925 [ 19194 ] {b4b58a4e-caf0-4957-9a58-40d68a34effb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:787e9680-75ba-4d74-986b-a1f07bb914cd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:56.900327 [ 19606 ] {fa0ebf23-bab3-449f-8faf-879cfde56167} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:a1e49bd3-f74f-4c2c-874e-85f434e02346'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38480) (comment: 02833_multiprewhere_extra_column.sql) (in query: CREATE DATABASE IF NOT EXISTS test_tlfxgc2u ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:56.910961 [ 19606 ] {fa0ebf23-bab3-449f-8faf-879cfde56167} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:a1e49bd3-f74f-4c2c-874e-85f434e02346'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:57.037922 [ 19194 ] {dced3bf7-2be5-4c4b-8484-bd18cc3dbc49} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:2078fe52-6fd5-4f65-84cb-efaa84b76b77'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38486) (comment: 01238_http_memory_tracking.sh) (in query: CREATE DATABASE IF NOT EXISTS test_jg4rp9ss ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:57.041917 [ 19194 ] {dced3bf7-2be5-4c4b-8484-bd18cc3dbc49} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:2078fe52-6fd5-4f65-84cb-efaa84b76b77'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:57.170144 [ 19194 ] {cb8d4851-108f-4d8d-97d1-18240ab715dd} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:15b5a0c3-3864-482e-b598-4087244e796a'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38494) (comment: 02919_insert_meet_eternal_hardware_error.sql) (in query: CREATE DATABASE IF NOT EXISTS test_e6kke5zk ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:57.260879 [ 16189 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:57.280536 [ 19194 ] {cb8d4851-108f-4d8d-97d1-18240ab715dd} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:15b5a0c3-3864-482e-b598-4087244e796a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:57.516462 [ 16390 ] {cd793258-7580-48f9-acff-36a00439ca91} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:156058a5-21b7-404e-b33f-083e0ca3c043'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38508) (comment: 02148_sql_user_defined_function_subquery.sql) (in query: CREATE DATABASE IF NOT EXISTS test_seg4dn2o ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:57.520555 [ 16390 ] {cd793258-7580-48f9-acff-36a00439ca91} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:156058a5-21b7-404e-b33f-083e0ca3c043'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:57.597139 [ 3912 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryMetricLogElement]: Failed to flush system log system.query_metric_log with 27 entries up to offset 2991: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.42 GiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037b1704e 10. ./src/Common/COW.h:293: DB::ColumnVector::cloneResized(unsigned long) const @ 0x0000000037b28bc1 11. DB::IColumn::cloneEmpty() const @ 0x000000002c156c44 12. ./build_docker/./src/Core/ColumnWithTypeAndName.cpp:21: DB::ColumnWithTypeAndName::cloneEmpty() const @ 0x000000002eb2689a 13. ./build_docker/./src/Core/Block.cpp:502: DB::Block::cloneEmpty() const @ 0x000000002eaff97e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:579: DB::MergeTreeDataPartWriterOnDisk::initOrAdjustDynamicStructureIfNeeded(DB::Block&) @ 0x0000000039bd16ae 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:177: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba565f 16. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 20. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 28. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000333e0dcc 29. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x00000000333de236 30. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba9d61 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba9b9f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:58.005106 [ 18727 ] {53a651ef-240b-49fe-86f0-e1638510f1cb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:a1cff92c-03e5-45f5-8bda-dd76329e0ec5'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38514) (comment: 02483_capnp_decimals.sh) (in query: CREATE DATABASE IF NOT EXISTS test_inawd769 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.012609 [ 18727 ] {53a651ef-240b-49fe-86f0-e1638510f1cb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:a1cff92c-03e5-45f5-8bda-dd76329e0ec5'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:58.087814 [ 19187 ] {c12349ab-d001-45fb-a27a-b0486c6a0a8b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56114) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.106385 [ 19187 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.158814 [ 10692 ] {4663313d-0eed-4754-b918-3737ad6e027c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56124) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.183338 [ 4528 ] {dd9ca633-b6f0-47e9-a476-e7285177b1f8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56130) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.192879 [ 10692 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.196298 [ 16109 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.215439 [ 4528 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.247181 [ 16194 ] {bf9a245d-928d-4950-ba0c-615cdc0dfe04} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.82 MiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55576) (comment: 03147_asof_join_ddb_missing.sql) (query 9, line 62) (in query: -- # 30 dates, 5 keys WITH build AS ( SELECT k, toDateTime('2001-01-01 00:00:00') + INTERVAL number MINUTE AS t, number AS v FROM numbers(30), (SELECT number AS k FROM numbers(5)) SETTINGS join_algorithm = 'default' ), probe AS ( SELECT k * 2 AS k, t - INTERVAL 30 SECOND AS t FROM build ) SELECT SUM(v) FROM probe ASOF JOIN build USING (k, t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.316331 [ 17731 ] {8b04c819-6453-4174-9623-c58d90aa0ffe} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:4f60fed8-9152-4624-92ba-e4c839daf079'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38526) (comment: 02185_values_schema_inference.sh) (in query: CREATE DATABASE IF NOT EXISTS test_0pwr7qgv ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.324086 [ 17731 ] {8b04c819-6453-4174-9623-c58d90aa0ffe} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: 'd32b9e83770c:9000:8a5f25d5-f9bb-4bed-98be-13029c664f92', current host ID: 'd32b9e83770c:9000:4f60fed8-9152-4624-92ba-e4c839daf079'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:58.404622 [ 3727 ] {71c45e7d-7e10-4b1d-9b03-0576bfa46af2::all_1_2_2_4} MutatePlainMergeTreeTask: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.26 GiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:58.412103 [ 10177 ] {2e341e88-f7e4-4043-afb5-0e7354ed345c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 5, line 6) (in query: SELECT snowflakeIDToDateTime();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:58.422797 [ 10177 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:58.471727 [ 19172 ] {fa3f5546-101f-4067-a88b-3607d4bce91a} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_4.txt' with part 'all_1_2_2_3' reason: 'Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.26 GiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a4a64d3 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991221 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 . (UNFINISHED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42486) (comment: 03285_materialize_ttl_only_drop_parts.sql) (query 13, line 24) (in query: ALTER TABLE test_03285_mat_ttl MODIFY TTL event_time - INTERVAL 3 MONTH SETTINGS mutations_sync = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a4a64d3 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991221 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.496175 [ 19172 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_4.txt' with part 'all_1_2_2_3' reason: 'Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.26 GiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a4a64d3 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991221 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a4a64d3 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991221 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.554279 [ 10177 ] {23316972-0527-46b1-bfae-78f560aff117} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 6, line 7) (in query: SELECT snowflakeIDToDateTime64();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:58.567908 [ 10177 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:58.597572 [ 10177 ] {f82df855-27a3-4270-a4dc-57a11f1aa4c8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 7, line 8) (in query: SELECT snowflakeIDToDateTime('invalid_snowflake');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.616926 [ 16194 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 2.82 MiB (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:14:58.641001 [ 10177 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.669089 [ 10177 ] {a340db4d-a317-45ee-98d0-1afdacb800e6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime64('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 8, line 9) (in query: SELECT snowflakeIDToDateTime64('invalid_snowflake');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.699648 [ 10177 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime64('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.778168 [ 10177 ] {e17664de-647a-4b2a-863e-be121972f76e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 9, line 10) (in query: SELECT snowflakeIDToDateTime(123::UInt64, 'invalid_epoch');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.782559 [ 10177 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.828502 [ 10177 ] {1163663a-f115-4a44-a2c5-86d0c0ad842f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 10, line 11) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, 'invalid_epoch');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.838991 [ 10177 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.882222 [ 10177 ] {7637408f-816e-495f-8d0c-cc15006eda5f} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 11, line 12) (in query: SELECT snowflakeIDToDateTime(123::UInt64, materialize(42));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.899701 [ 10177 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.953205 [ 10177 ] {87611685-fadd-4243-825d-06b4995b75ac} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 12, line 13) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, materialize(42));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:58.964020 [ 10177 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:59.018309 [ 10177 ] {41741aa5-afdf-481e-85c6-a92e340d787e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 13, line 14) (in query: SELECT snowflakeIDToDateTime(123::UInt64, 42, 42);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:59.043015 [ 10177 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:59.078375 [ 16381 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:14:59.120454 [ 10177 ] {caeaafac-99be-415d-a643-2699a9903e51} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime64'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 14, line 15) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, 42, 42);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:59.125752 [ 10177 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime64'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:14:59.173205 [ 10177 ] {1eb1271a-eb41-4a3a-afff-eb20c71734d9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 15, line 16) (in query: SELECT snowflakeIDToDateTime(123::UInt64, 42, 'UTC', 'too_many_args');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:59.189194 [ 10177 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:59.242836 [ 10177 ] {f119e972-41d0-46b6-8eb7-25a0029203fd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56164) (comment: 01942_snowflakeIDToDateTime.sql) (query 16, line 17) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, 42, 'UTC', 'too_many_args');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:59.247705 [ 10177 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:14:59.585589 [ 18727 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.586215 [ 18727 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.666406 [ 18727 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.667073 [ 18727 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.668958 [ 18727 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.669523 [ 18727 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.925678 [ 15982 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.926929 [ 4550 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.927380 [ 4550 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.927985 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.936224 [ 15982 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.26 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:14:59.936649 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.26 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:00.337211 [ 3727 ] {71c45e7d-7e10-4b1d-9b03-0576bfa46af2::all_1_2_2_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.26 GiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c3f 12. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:55: DB::CompressionCodecMultiple::doCompressData(char const*, unsigned int, char*) const @ 0x000000003dd6e77e 13. ./build_docker/./src/Compression/ICompressionCodec.cpp:95: DB::ICompressionCodec::compress(char const*, unsigned int, char*) const @ 0x000000003de7de75 14. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:36: DB::CompressedWriteBuffer::nextImpl() @ 0x000000003dd3a7fb 15. DB::WriteBuffer::next() @ 0x0000000008c37ea1 16. ./src/IO/HashingWriteBuffer.h:63: DB::HashingWriteBuffer::nextImpl() @ 0x000000003952910e 17. ./src/IO/WriteBuffer.h:53: DB::MergeTreeDataPartWriterCompact::writeDataBlock(DB::Block const&, std::vector> const&) @ 0x0000000039baad25 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:210: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x0000000039ba926d 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:202: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba7015 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1256: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003a09961d 22. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a1053f3 23. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003a0f4572 24. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2003: DB::ExecutableTaskDropTTLExpiredPartsDecorator::executeStep() @ 0x000000003a0f2c0b 25. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000003a0a497f 26. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:00.338273 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {71c45e7d-7e10-4b1d-9b03-0576bfa46af2::all_1_2_2_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.26 GiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c3f 12. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:55: DB::CompressionCodecMultiple::doCompressData(char const*, unsigned int, char*) const @ 0x000000003dd6e77e 13. ./build_docker/./src/Compression/ICompressionCodec.cpp:95: DB::ICompressionCodec::compress(char const*, unsigned int, char*) const @ 0x000000003de7de75 14. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:36: DB::CompressedWriteBuffer::nextImpl() @ 0x000000003dd3a7fb 15. DB::WriteBuffer::next() @ 0x0000000008c37ea1 16. ./src/IO/HashingWriteBuffer.h:63: DB::HashingWriteBuffer::nextImpl() @ 0x000000003952910e 17. ./src/IO/WriteBuffer.h:53: DB::MergeTreeDataPartWriterCompact::writeDataBlock(DB::Block const&, std::vector> const&) @ 0x0000000039baad25 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:210: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x0000000039ba926d 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:202: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba7015 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1256: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003a09961d 22. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a1053f3 23. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003a0f4572 24. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2003: DB::ExecutableTaskDropTTLExpiredPartsDecorator::executeStep() @ 0x000000003a0f2c0b 25. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000003a0a497f 26. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:00.356507 [ 18727 ] {28340b18-7edd-436c-bf88-7506e4f64b5f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56374) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:15:00.373356 [ 18727 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:00.391856 [ 15982 ] {5aaf879a-3f45-4015-829a-16f3dc5c23bb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56418) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:00.433123 [ 15982 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b205851 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 11. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 12. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:00.447749 [ 17376 ] {843dcfc2-9b35-4500-9dc0-42677dd6dad6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56382) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:15:00.463550 [ 17376 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:00.475883 [ 4550 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:00.961845 [ 18391 ] {27d67a2b-11ee-4fd1-85f7-08e6da83def7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41662) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:15:00.985022 [ 18391 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:01.022869 [ 16230 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:01.687085 [ 17731 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.30 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:01.688105 [ 15982 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:01.720274 [ 3738 ] {71c45e7d-7e10-4b1d-9b03-0576bfa46af2::all_1_2_2_4} MutatePlainMergeTreeTask: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.30 GiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:01.721215 [ 16233 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.30 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:01.721816 [ 16233 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.30 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:01.769266 [ 15982 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.30 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:01.769850 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.30 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:02.450438 [ 15982 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:02.769880 [ 18389 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000032f7399c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x000000003b1c4451 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr, std::allocator>>>&, std::shared_ptr&, 0>(std::allocator const&, std::shared_ptr, std::allocator>>>&, std::shared_ptr&) @ 0x000000002f25cae8 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20c9da 10. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 11. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x00000000339b7b59 12. ./build_docker/./src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x00000000339a5a95 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:03.240718 [ 3739 ] {5a642d2d-8981-43c6-8ee1-d369be3bbe53::202511_1_76_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.30 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column event_time): (while reading from part /var/lib/clickhouse/store/5a6/5a642d2d-8981-43c6-8ee1-d369be3bbe53/202511_1_71_14/ in table system.asynchronous_metric_log (5a642d2d-8981-43c6-8ee1-d369be3bbe53) located on disk default of type local, from mark 2 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c115fc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4e9f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:03.278596 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5a642d2d-8981-43c6-8ee1-d369be3bbe53::202511_1_76_15}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.30 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column event_time): (while reading from part /var/lib/clickhouse/store/5a6/5a642d2d-8981-43c6-8ee1-d369be3bbe53/202511_1_71_14/ in table system.asynchronous_metric_log (5a642d2d-8981-43c6-8ee1-d369be3bbe53) located on disk default of type local, from mark 2 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c115fc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4e9f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:03.292100 [ 15982 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41854, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:03.292644 [ 15982 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41854, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:03.292794 [ 17376 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41844, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:03.293263 [ 17376 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:41844, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:03.355250 [ 18096 ] {5365ef86-e0ab-4eb2-9677-cf863c0a94fd} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41862) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:15:03.355390 [ 18721 ] {d0ebfde0-09e6-47af-894a-e5dd3cb5d1d0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41878) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_7' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:15:03.361154 [ 18096 ] {5365ef86-e0ab-4eb2-9677-cf863c0a94fd} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41862). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x000000003aea5649 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:03.361176 [ 18721 ] {d0ebfde0-09e6-47af-894a-e5dd3cb5d1d0} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41878). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x000000003aea5649 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:03.366359 [ 18096 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:03.373635 [ 18721 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:03.850011 [ 3738 ] {71c45e7d-7e10-4b1d-9b03-0576bfa46af2::all_1_2_2_4} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.30 GiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c00 12. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:55: DB::CompressionCodecMultiple::doCompressData(char const*, unsigned int, char*) const @ 0x000000003dd6e77e 13. ./build_docker/./src/Compression/ICompressionCodec.cpp:95: DB::ICompressionCodec::compress(char const*, unsigned int, char*) const @ 0x000000003de7de75 14. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:36: DB::CompressedWriteBuffer::nextImpl() @ 0x000000003dd3a7fb 15. DB::WriteBuffer::next() @ 0x0000000008c37ea1 16. ./src/IO/HashingWriteBuffer.h:63: DB::HashingWriteBuffer::nextImpl() @ 0x000000003952910e 17. ./src/IO/WriteBuffer.h:53: DB::MergeTreeDataPartWriterCompact::writeDataBlock(DB::Block const&, std::vector> const&) @ 0x0000000039baad25 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:210: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x0000000039ba926d 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:202: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba7015 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1256: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003a09961d 22. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a1053f3 23. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003a0f4572 24. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2003: DB::ExecutableTaskDropTTLExpiredPartsDecorator::executeStep() @ 0x000000003a0f2c0b 25. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000003a0a497f 26. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:03.854548 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {71c45e7d-7e10-4b1d-9b03-0576bfa46af2::all_1_2_2_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.30 GiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c00 12. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:55: DB::CompressionCodecMultiple::doCompressData(char const*, unsigned int, char*) const @ 0x000000003dd6e77e 13. ./build_docker/./src/Compression/ICompressionCodec.cpp:95: DB::ICompressionCodec::compress(char const*, unsigned int, char*) const @ 0x000000003de7de75 14. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:36: DB::CompressedWriteBuffer::nextImpl() @ 0x000000003dd3a7fb 15. DB::WriteBuffer::next() @ 0x0000000008c37ea1 16. ./src/IO/HashingWriteBuffer.h:63: DB::HashingWriteBuffer::nextImpl() @ 0x000000003952910e 17. ./src/IO/WriteBuffer.h:53: DB::MergeTreeDataPartWriterCompact::writeDataBlock(DB::Block const&, std::vector> const&) @ 0x0000000039baad25 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:210: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x0000000039ba926d 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:202: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba7015 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1256: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000003a09961d 22. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x000000003a1053f3 23. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1394: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000003a0f4572 24. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2003: DB::ExecutableTaskDropTTLExpiredPartsDecorator::executeStep() @ 0x000000003a0f2c0b 25. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000003a0a497f 26. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:03.955320 [ 17376 ] {5ffd8cbd-e430-4de2-95c8-a4336c68dbe5} executeQuery: Code: 36. DB::Exception: Identifier 'test_foo_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41926) (comment: 03234_enable_secure_identifiers.sql) (query 2, line 2) (in query: CREATE TABLE `test_foo_#` ( `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000003dfa9839 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003dfa8be5 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e0a7cc9 9. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df24169 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:03.967498 [ 17376 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'test_foo_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000003dfa9839 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003dfa8be5 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e0a7cc9 9. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df24169 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:04.051755 [ 17376 ] {5909be85-3c51-42df-ba26-ca1723832e76} executeQuery: Code: 36. DB::Exception: Identifier 'insecure_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41926) (comment: 03234_enable_secure_identifiers.sql) (query 5, line 16) (in query: CREATE TABLE test_foo ( `insecure_#` Int8, `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:04.058073 [ 17376 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'insecure_#' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:04.179579 [ 17376 ] {ec510335-915c-49ac-9b19-5967893c0788} executeQuery: Code: 36. DB::Exception: Identifier 'insecure_'' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41926) (comment: 03234_enable_secure_identifiers.sql) (query 7, line 29) (in query: CREATE TABLE test_foo ( `insecure_'` Int8, `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:04.246109 [ 17376 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'insecure_'' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:04.279096 [ 16186 ] {fffe89cd-1213-4362-b842-7d7691a3804c} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41868). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41868) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed4b32 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:04.279093 [ 18700 ] {d035164d-448d-4e4a-ba91-1655116f2a50} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41890). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41890) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: SELECT count() FROM numbers_mt(10000) WHERE rand() = 0 FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed4b32 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:04.290633 [ 16186 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41868). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed4b32 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:04.294419 [ 18700 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:41890). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed4b32 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:04.323602 [ 17376 ] {f371d35d-c67e-4dcc-99fa-38e35f4cd4c0} executeQuery: Code: 36. DB::Exception: Identifier 'insecure_"' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41926) (comment: 03234_enable_secure_identifiers.sql) (query 9, line 42) (in query: CREATE TABLE test_foo ( `insecure_"` Int8, `date` Date, `town` LowCardinality(String), ) ENGINE = MergeTree PRIMARY KEY (town, date) PARTITION BY toYear(date) COMMENT 'test' -- to end ENGINE definition, so SETTINGS will be in the query level SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:04.327983 [ 17376 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'insecure_"' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTColumnDeclaration.cpp:69: DB::ASTColumnDeclaration::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003decc7fb 7. ./src/Parsers/IAST.h:266: DB::ASTColumnsElement::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df16f13 8. ./src/Parsers/IAST.h:266: DB::ASTExpressionList::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df71308 9. ./src/Parsers/IAST.h:266: DB::ASTColumns::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df1cd86 10. ./src/Parsers/IAST.h:266: DB::ASTCreateQuery::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003df27dbb 11. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 12. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:15:05.840714 [ 17376 ] {1dfa9e2b-7bcc-4175-a0bd-f8050e2498dd} executeQuery: Code: 36. DB::Exception: Identifier 'test_foo$' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41926) (comment: 03234_enable_secure_identifiers.sql) (query 20, line 106) (in query: -- SHOW CREATE .. query contains an insecure identifier (`test_foo$`) with `enforce_strict_identifier_format` SHOW CREATE TABLE `test_foo$` SETTINGS enforce_strict_identifier_format=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000003dfa9839 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003dfa8be5 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e0a7cc9 9. ./src/Parsers/IAST.h:266: DB::ASTQueryWithTableAndOutputImpl::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e2a43f4 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:05.845204 [ 17376 ] {} TCPHandler: Code: 36. DB::Exception: Identifier 'test_foo$' contains characters other than alphanumeric and cannot be when enforce_strict_identifier_format is enabled. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Parsers/IAST.cpp:318: DB::IAST::FormatSettings::checkIdentifier(String const&) const @ 0x000000003e183c50 5. ./build_docker/./src/Parsers/IAST.cpp:270: DB::IAST::FormatSettings::writeIdentifier(DB::WriteBuffer&, String const&, bool) const @ 0x000000003e1831fa 6. ./build_docker/./src/Parsers/ASTIdentifier.cpp:0: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const::$_0::operator()(String const&) const @ 0x000000003dfa9839 7. ./build_docker/./src/Parsers/ASTIdentifier.cpp:149: DB::ASTIdentifier::formatImplWithoutAlias(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003dfa8be5 8. ./build_docker/./src/Parsers/ASTWithAlias.cpp:35: DB::ASTWithAlias::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e0a7cc9 9. ./src/Parsers/IAST.h:266: DB::ASTQueryWithTableAndOutputImpl::formatQueryImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e2a43f4 10. ./build_docker/./src/Parsers/ASTQueryWithOutput.cpp:40: DB::ASTQueryWithOutput::formatImpl(DB::WriteBuffer&, DB::IAST::FormatSettings const&, DB::IAST::FormatState&, DB::IAST::FormatStateStacked) const @ 0x000000003e003c88 11. DB::IAST::format(DB::WriteBuffer&, DB::IAST::FormatSettings const&) const @ 0x000000000ee50145 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1130: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382780c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:07.185624 [ 16203 ] {39b04dda-634a-4d55-bc0e-f807c11fb5f5} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: In scope SELECT 1 AS a, a + a AS b, b + b AS c, c + c AS d, d + d AS e, e + e AS f, f + f AS g, g + g AS h, h + h AS i, i + i AS j, j + j AS k, k + k AS l, l + l AS m, m + m AS n, n + n AS o, o + o AS p, p + p AS q, q + q AS r, r + r AS s, s + s AS t, t + t AS u, u + u AS v, v + v AS w, w + w AS x, x + x AS y, y + y AS z. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38232) (comment: 00988_expansion_aliases_limit.sql) (query 1, line 1) (in query: SELECT 1 AS a, a + a AS b, b + b AS c, c + c AS d, d + d AS e, e + e AS f, f + f AS g, g + g AS h, h + h AS i, i + i AS j, j + j AS k, k + k AS l, l + l AS m, m + m AS n, n + n AS o, o + o AS p, p + p AS q, q + q AS r, r + r AS s, s + s AS t, t + t AS u, u + u AS v, v + v AS w, w + w AS x, x + x AS y, y + y AS z;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008cedff4 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insert(DB::Field const&) @ 0x0000000037b0f35b 13. ./build_docker/./src/DataTypes/IDataType.cpp:75: DB::IDataType::createColumnConst(unsigned long, DB::Field const&) const @ 0x000000002f4b3d79 14. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000018860849 15. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001885f650 16. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001885be15 17. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018829585 18. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001881feb2 19. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001881846b 20. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188146cd 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1243: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030447274 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1494: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449c4e 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 2025.11.13 09:15:07.193174 [ 16203 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.25 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: In scope SELECT 1 AS a, a + a AS b, b + b AS c, c + c AS d, d + d AS e, e + e AS f, f + f AS g, g + g AS h, h + h AS i, i + i AS j, j + j AS k, k + k AS l, l + l AS m, m + m AS n, n + n AS o, o + o AS p, p + p AS q, q + q AS r, r + r AS s, s + s AS t, t + t AS u, u + u AS v, v + v AS w, w + w AS x, x + x AS y, y + y AS z. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008cedff4 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insert(DB::Field const&) @ 0x0000000037b0f35b 13. ./build_docker/./src/DataTypes/IDataType.cpp:75: DB::IDataType::createColumnConst(unsigned long, DB::Field const&) const @ 0x000000002f4b3d79 14. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000018860849 15. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x000000001885f650 16. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001885be15 17. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000018829585 18. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001881feb2 19. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001881846b 20. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188146cd 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1243: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030447274 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1494: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449c4e 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 2025.11.13 09:15:08.862876 [ 18700 ] {d1d45c7f-a862-497d-a1e4-d7feaabdc4e8} executeQuery: Code: 36. DB::Exception: Cannot parse ClickHouse version here: a.a: in attempt to set the value of setting 'compatibility' to 'a.a'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42106) (comment: 02503_bad_compatibility_setting.sql) (query 1, line 1) (in query: set compatibility='a.a';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Core/SettingsChangesHistory.cpp:32: DB::ClickHouseVersion::ClickHouseVersion(std::basic_string_view>) @ 0x000000002f0227a2 5. ./build_docker/./src/Core/Settings.cpp:6382: DB::SettingsImpl::applyCompatibilitySetting(String const&) @ 0x000000002edc5d9b 6. ./build_docker/./src/Core/Settings.cpp:6359: DB::SettingsImpl::set(std::basic_string_view>, DB::Field const&) @ 0x000000002edc5508 7. ./build_docker/./src/Core/Settings.cpp:6477: DB::Settings::set(std::basic_string_view>, DB::Field const&) @ 0x000000002edcd3cc 8. ./build_docker/./src/Interpreters/Context.cpp:2598: DB::Context::applySettingChangeWithLock(DB::SettingChange const&, std::lock_guard const&) @ 0x00000000317ea274 9. ./build_docker/./src/Interpreters/Context.cpp:2622: DB::Context::applySettingsChanges(DB::SettingsChanges const&) @ 0x00000000317eb826 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:30: DB::InterpreterSetQuery::execute() @ 0x0000000032da5c59 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:15:08.878978 [ 18700 ] {} TCPHandler: Code: 36. DB::Exception: Cannot parse ClickHouse version here: a.a: in attempt to set the value of setting 'compatibility' to 'a.a'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Core/SettingsChangesHistory.cpp:32: DB::ClickHouseVersion::ClickHouseVersion(std::basic_string_view>) @ 0x000000002f0227a2 5. ./build_docker/./src/Core/Settings.cpp:6382: DB::SettingsImpl::applyCompatibilitySetting(String const&) @ 0x000000002edc5d9b 6. ./build_docker/./src/Core/Settings.cpp:6359: DB::SettingsImpl::set(std::basic_string_view>, DB::Field const&) @ 0x000000002edc5508 7. ./build_docker/./src/Core/Settings.cpp:6477: DB::Settings::set(std::basic_string_view>, DB::Field const&) @ 0x000000002edcd3cc 8. ./build_docker/./src/Interpreters/Context.cpp:2598: DB::Context::applySettingChangeWithLock(DB::SettingChange const&, std::lock_guard const&) @ 0x00000000317ea274 9. ./build_docker/./src/Interpreters/Context.cpp:2622: DB::Context::applySettingsChanges(DB::SettingsChanges const&) @ 0x00000000317eb826 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:30: DB::InterpreterSetQuery::execute() @ 0x0000000032da5c59 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:15:10.690765 [ 18728 ] {37d8a872-fa94-4a18-843c-8da8f3bcfb07} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statements with nondeterministic deterministic functions cannot be applied on fly. Function 'rand' is non-deterministic. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42142) (comment: 03047_on_fly_mutations_non_deterministic.sql) (query 7, line 12) (in query: SELECT * FROM t_lightweight_mut_2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/AlterConversions.cpp:99: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x0000000039afa409 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8688: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039a3e103 6. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:158: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x000000003c340b24 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:53: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c33f0fd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:26: DB::MergeTreeReadPoolInOrder::MergeTreeReadPoolInOrder(bool, DB::MergeTreeReadType, DB::RangesInDataParts, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c3f8609 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolInOrder* std::construct_at[abi:ne190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolInOrder*>(DB::MergeTreeReadPoolInOrder*, bool&, DB::MergeTreeReadType&, DB::RangesInDataParts&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x000000003c3008c8 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readInOrder(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings, DB::MergeTreeReadType, unsigned long) @ 0x000000003c271c85 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:763: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003c2781bc 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:965: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003c27aace 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2128: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003c2c322f 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2226: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c9ebb 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:15:10.698019 [ 18728 ] {} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statements with nondeterministic deterministic functions cannot be applied on fly. Function 'rand' is non-deterministic. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/AlterConversions.cpp:99: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x0000000039afa409 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8688: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039a3e103 6. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:158: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x000000003c340b24 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:53: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c33f0fd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:26: DB::MergeTreeReadPoolInOrder::MergeTreeReadPoolInOrder(bool, DB::MergeTreeReadType, DB::RangesInDataParts, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c3f8609 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolInOrder* std::construct_at[abi:ne190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolInOrder*>(DB::MergeTreeReadPoolInOrder*, bool&, DB::MergeTreeReadType&, DB::RangesInDataParts&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x000000003c3008c8 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readInOrder(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings, DB::MergeTreeReadType, unsigned long) @ 0x000000003c271c85 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:763: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003c2781bc 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:965: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003c27aace 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2128: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003c2c322f 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2226: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c9ebb 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:15:11.640721 [ 18112 ] {e997e56f-d46b-4618-b63f-531cad5a2400} executeQuery: Code: 57. DB::Exception: Table test_3.a already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42012) (comment: 03168_inconsistent_ast_formatting.sql) (query 1, line 6) (in query: create table a (x Int8) engine Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:15:11.647374 [ 18112 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.a already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:15:12.440249 [ 18376 ] {99fd6627-a004-49ed-89dd-e67f9eae6df6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58868) (comment: 02806_system_parts_columns_modification_time.gen.sql) (in query: DROP DATABASE IF EXISTS test_3drhh7q0 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:12.444218 [ 18376 ] {99fd6627-a004-49ed-89dd-e67f9eae6df6} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:12.477746 [ 18700 ] {eee62774-1ba0-4cec-b51f-e064f0fc74cd} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58870) (comment: 02806_system_parts_columns_modification_time.gen.sql) (in query: DROP DATABASE IF EXISTS test_3drhh7q0 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:12.483872 [ 18700 ] {eee62774-1ba0-4cec-b51f-e064f0fc74cd} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:13.187671 [ 18728 ] {82b53528-6af5-4a24-ac1d-9a8edf1e8fcb} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic and cannot be applied on fly. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42142) (comment: 03047_on_fly_mutations_non_deterministic.sql) (query 13, line 21) (in query: SELECT * FROM t_lightweight_mut_2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/AlterConversions.cpp:95: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x0000000039afa2de 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8688: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039a3e103 6. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:158: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x000000003c340b24 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:53: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c33f0fd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:26: DB::MergeTreeReadPoolInOrder::MergeTreeReadPoolInOrder(bool, DB::MergeTreeReadType, DB::RangesInDataParts, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c3f8609 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolInOrder* std::construct_at[abi:ne190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolInOrder*>(DB::MergeTreeReadPoolInOrder*, bool&, DB::MergeTreeReadType&, DB::RangesInDataParts&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x000000003c3008c8 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readInOrder(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings, DB::MergeTreeReadType, unsigned long) @ 0x000000003c271c85 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:763: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003c2781bc 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:965: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003c27aace 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2128: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003c2c322f 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2226: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c9ebb 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:15:13.226692 [ 18728 ] {} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic and cannot be applied on fly. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/AlterConversions.cpp:95: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x0000000039afa2de 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8688: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039a3e103 6. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:158: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x000000003c340b24 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:53: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c33f0fd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:26: DB::MergeTreeReadPoolInOrder::MergeTreeReadPoolInOrder(bool, DB::MergeTreeReadType, DB::RangesInDataParts, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c3f8609 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolInOrder* std::construct_at[abi:ne190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolInOrder*>(DB::MergeTreeReadPoolInOrder*, bool&, DB::MergeTreeReadType&, DB::RangesInDataParts&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x000000003c3008c8 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readInOrder(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings, DB::MergeTreeReadType, unsigned long) @ 0x000000003c271c85 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:763: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003c2781bc 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:965: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003c27aace 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2128: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003c2c322f 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2226: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c9ebb 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:15:15.126169 [ 18096 ] {9fb7e078-18f5-47aa-821c-9205bdc2053a} executeQuery: Code: 43. DB::Exception: Illegal type FixedString(1) of first argument of function port. Must be String.: In scope SELECT port(toFixedString('', 1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42064) (comment: 01284_port.gen.sql) (query 16, line 19) (in query: -- unsupported /* ILLEGAL_TYPE_OF_ARGUMENT */ select port(toFixedString('', 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0ba49e 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:15.131567 [ 18096 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type FixedString(1) of first argument of function port. Must be String.: In scope SELECT port(toFixedString('', 1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0ba49e 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:15.132097 [ 17385 ] {9ad3d9cc-c6e8-43f8-bdb4-cb1927a48299} executeQuery: Code: 60. DB::Exception: Could not find table: t22. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42136) (comment: 03325_alter_ast_format.sql) (query 1, line 1) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/74369 -- Note that this is fixed by enabling format_alter_operations_with_parentheses. Otherwise in debug mode it'd throw a LOGICAL_ERROR ALTER TABLE t22 (DELETE WHERE ('å«' = c1) OR ((792.3673220441809 = c0) AND (c0 = c1))), (MODIFY SETTING persistent = 1), (UPDATE c1 = 'would' WHERE NOT f2()), (MODIFY SETTING persistent = 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:15:15.137164 [ 17385 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: t22. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:15:16.341304 [ 16207 ] {ec514143-1c9f-49c8-bfdf-1dfa6e1ad54a} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42190) (comment: 01320_optimize_skip_unused_shards_no_non_deterministic.sql) (query 7, line 12) (in query: select * from dist_01320 where key = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1575: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003845ff14 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003845b3eb 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:901: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c66c19 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:15:16.346262 [ 16207 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/StorageDistributed.cpp:1575: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x000000003845ff14 5. ./build_docker/./src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x000000003845b3eb 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:901: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c66c19 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:15:16.398928 [ 17226 ] {c12193cb-d5c6-423d-a57d-9d686735b11f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=851). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42152) (comment: 00192_least_greatest.sql) (query 12, line 12) (in query: SELECT greatest(today(), yesterday() + 10) - today();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:15:16.408842 [ 17226 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=851). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:15:16.470448 [ 18096 ] {5b69dce9-7eae-4307-91d0-a24eb3e8eecf} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of second argument of function port. Must be UInt16.: In scope SELECT port('', 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42064) (comment: 01284_port.gen.sql) (query 17, line 21) (in query: /* ILLEGAL_TYPE_OF_ARGUMENT */ select port('', 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0ba6fe 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:16.474828 [ 18096 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of second argument of function port. Must be UInt16.: In scope SELECT port('', 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0ba6fe 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:16.837558 [ 18376 ] {7b1db48d-ddac-44fb-b1cb-de6a4db77268} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `Price` in scope SELECT Price FROM test_02428_pv1. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42220) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: SELECT Price FROM test_02428_pv1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:15:16.845338 [ 18376 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `Price` in scope SELECT Price FROM test_02428_pv1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:15:17.531708 [ 16200 ] {} DynamicQueryHandler: Code: 516. DB::Exception: header_test: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./build_docker/./src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x000000002e25ca05 4. ./build_docker/./src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000032ff8d71 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:251: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af54dea 6. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 7. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:18.271473 [ 16200 ] {} DynamicQueryHandler: Code: 516. DB::Exception: Got an empty user name from X-ClickHouse HTTP headers. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:47: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, DB::HTTPHandlerConnectionConfig const&, std::shared_ptr, std::shared_ptr) @ 0x000000003af55c9b 5. ./build_docker/./src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000003acd4233 6. ./build_docker/./src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd524e 7. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:18.427935 [ 18096 ] {9559cfa5-d7ed-404e-bfdc-8a5f022b4f49} executeQuery: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 3, should be 1 or 2: In scope SELECT port('', 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42064) (comment: 01284_port.gen.sql) (query 18, line 22) (in query: /* NUMBER_OF_ARGUMENTS_DOESNT_MATCH */ select port('', 1, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008c2306d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0ba229 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:18.433088 [ 18096 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 3, should be 1 or 2: In scope SELECT port('', 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008c2306d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0ba229 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:19.495590 [ 4028 ] {e41e8586-8966-453d-a1c8-81f12e52760e} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1000.297498 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55712) (comment: 02786_max_execution_time_leaf.sql) (query 2, line 3) (in query: SELECT count() AS `count()` FROM view(SELECT * FROM numbers(100000000000)) AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:15:19.506216 [ 4028 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1000.297498 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:19.536588 [ 16223 ] {706f0c39-d179-437a-b6c5-8c593017536f} executeQuery: Code: 159. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Timeout exceeded: elapsed 1000.297498 ms, maximum: 1000 ms. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42316) (comment: 02786_max_execution_time_leaf.sql) (query 2, line 3) (in query: SELECT count() FROM cluster('test_cluster_two_shards', view( SELECT * FROM numbers(100000000000) )) SETTINGS max_execution_time_leaf = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:15:19.553743 [ 16223 ] {} TCPHandler: Code: 159. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Timeout exceeded: elapsed 1000.297498 ms, maximum: 1000 ms. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:19.708816 [ 16703 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database header_test does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:539: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x0000000031ae3afe 5. ./build_docker/./src/Interpreters/Context.cpp:2800: DB::Context::setCurrentDatabaseWithLock(String const&, std::lock_guard const&) @ 0x00000000317c67ce 6. ./build_docker/./src/Interpreters/Context.cpp:2808: DB::Context::setCurrentDatabase(String const&) @ 0x00000000317eeb4b 7. ./build_docker/./src/Server/HTTPHandler.cpp:403: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdcbfe 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:20.225633 [ 6070 ] {8d18a18c-4394-499d-840c-f41e67788dcc} executeQuery: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53656) (comment: 01399_http_request_headers.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Formats/FormatFactory.cpp:75: DB::FormatFactory::getCreators(String const&) const @ 0x000000003af94f4e 5. ./build_docker/./src/Formats/FormatFactory.cpp:555: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003afa657a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1847: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000033842658 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:15:20.479986 [ 18096 ] {e1dc02d5-1482-4674-b530-7f1f393a5e72} executeQuery: Code: 43. DB::Exception: Illegal type FixedString(1) of first argument of function port. Must be String.: In scope SELECT port(toFixedString('', 1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42064) (comment: 01284_port.gen.sql) (query 43, line 53) (in query: -- unsupported /* ILLEGAL_TYPE_OF_ARGUMENT */ select port(toFixedString('', 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0ba49e 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:20.484543 [ 18096 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type FixedString(1) of first argument of function port. Must be String.: In scope SELECT port(toFixedString('', 1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0ba49e 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:21.096956 [ 6070 ] {8d18a18c-4394-499d-840c-f41e67788dcc} executeQuery: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Formats/FormatFactory.cpp:75: DB::FormatFactory::getCreators(String const&) const @ 0x000000003af94f4e 5. ./build_docker/./src/Formats/FormatFactory.cpp:591: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003afa8604 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1728: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>)::$_1::operator()() const @ 0x000000003384d21c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1907: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000338459bb 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:15:21.108274 [ 6070 ] {8d18a18c-4394-499d-840c-f41e67788dcc} DynamicQueryHandler: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Formats/FormatFactory.cpp:75: DB::FormatFactory::getCreators(String const&) const @ 0x000000003af94f4e 5. ./build_docker/./src/Formats/FormatFactory.cpp:555: DB::FormatFactory::getOutputFormatParallelIfPossible(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000003afa657a 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1847: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000033842658 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:21.844650 [ 18096 ] {b3bceb43-4b70-47ac-8984-5ce917a10a52} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of second argument of function portRFC. Must be UInt16.: In scope SELECT portRFC('', 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42064) (comment: 01284_port.gen.sql) (query 44, line 55) (in query: /* ILLEGAL_TYPE_OF_ARGUMENT */ select portRFC('', 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0bd23e 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:21.849598 [ 18096 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of second argument of function portRFC. Must be UInt16.: In scope SELECT portRFC('', 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0bd23e 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:22.092511 [ 16703 ] {b9b31c25-8166-4349-87c1-c121d30099fa} executeQuery: Code: 57. DB::Exception: Table test_7.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41720) (comment: 03170_part_offset_as_table_column.sql) (query 1, line 1) (in query: CREATE TABLE test_table (`key` UInt32, `_part_offset` DEFAULT 0) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 9091, min_bytes_for_wide_part = 966168357, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 316671618, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 30396813, merge_max_block_size = 14297, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7090491740, index_granularity_bytes = 11561721, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 93948, primary_key_compress_block_size = 36021, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:15:22.099476 [ 16703 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:15:22.698045 [ 16230 ] {ca5cd63d-bf55-4008-90d1-61f03d8bd648} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41936) (comment: 00700_decimal_complex_types.sql) (query 123, line 161) (in query: SELECT number % 2 ? toDecimal32('32.1', 5) : toDecimal32('32.2', 1) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000030c0b779 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309c6b35 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d1c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:22.704531 [ 16230 ] {} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000030c0b779 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309c6b35 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d1c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:23.108734 [ 18096 ] {1bff92be-3441-4ef3-9386-1339657cd6cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 3, should be 1 or 2: In scope SELECT portRFC('', 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42064) (comment: 01284_port.gen.sql) (query 45, line 56) (in query: /* NUMBER_OF_ARGUMENTS_DOESNT_MATCH */ select portRFC('', 1, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008c2306d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0bcd69 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:23.121097 [ 18096 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 3, should be 1 or 2: In scope SELECT portRFC('', 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x0000000008c2306d 4. DB::FunctionPortImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b0bcd69 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:23.367561 [ 5803 ] {02b6b2f9-bfec-448e-8a09-69889743a92c} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41766) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: INSERT INTO test_02428_pv1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000038356007 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd6d680 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000032ad1b23 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ada2a3 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000032adffb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:15:23.376732 [ 5803 ] {} TCPHandler: Code: 48. DB::Exception: Method write is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000038356007 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd6d680 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000032ad1b23 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ada2a3 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000032adffb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:15:23.419630 [ 3498 ] {} test_15.partitioned_table (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:15:23.419739 [ 3504 ] {} test_7.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:15:23.419817 [ 3626 ] {} test_15.data_rep_02228 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:15:23.421198 [ 3128 ] {} test_1.t_mutations_nondeterministic (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:15:23.421256 [ 3622 ] {} test_15.table_3 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:15:23.421334 [ 3623 ] {} test_7.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:15:23.421215 [ 3125 ] {} test_omnb98dj.test_02428_Catalog (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:15:23.421729 [ 3124 ] {} test_9.test_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:15:23.429282 [ 3121 ] {} test_u21noyth.mutations_r2 (18579a2b-ead5-4580-acdb-a86c12c0666e): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003d0a7a6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160d5e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1565: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003d16fe74 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1358: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff8840 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:301: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff78a0 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:375: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9ec7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:337: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9bca 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a2ef3f9 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3830: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000038a68019 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:423: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_2, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c91f9f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:23.430031 [ 3121 ] {} test_u21noyth.mutations_r1 (a5ba0600-5f6c-4589-a465-0b49cfb2d844): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003d0a7a6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160d5e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1565: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003d16fe74 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1358: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff8840 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:301: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff78a0 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:375: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9ec7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:337: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9bca 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a2ef3f9 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3830: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000038a68019 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:423: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_2, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c91f9f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:23.430633 [ 3121 ] {} test_u21noyth.mutations_cleaner_r1 (fe184ee6-699a-4a98-a572-6a97e3bddcc7): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003d0a7a6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160d5e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1565: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003d16fe74 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1358: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff8840 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:301: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff78a0 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:375: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9ec7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:337: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9bca 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a2ef3f9 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3830: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000038a68019 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:423: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_2, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c91f9f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:23.430880 [ 3145 ] {} test_u21noyth.mutations_cleaner_r2 (3665afb5-6fe3-4d5a-9ae0-e3a8304e8768): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003d0a7a6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160d5e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1565: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003d16fe74 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1358: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff8840 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:301: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff78a0 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:375: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9ec7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:337: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9bca 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a2ef3f9 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3830: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000038a68019 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:423: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_2, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c91f9f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:23.545021 [ 6070 ] {8823656a-0c89-42c8-8bed-72917ec75226} executeQuery: Code: 60. DB::Exception: Table test_brpgomjs.target_table does not exist. Maybe you meant test_1.right_table?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60688) (comment: 01064_incremental_streaming_from_2_src_with_feedback.sql) (in query: DROP DATABASE IF EXISTS test_brpgomjs SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:775: DB::StorageMaterializedView::getTargetTable() const @ 0x000000003873c740 8. ./src/Storages/StorageMaterializedView.h:38: DB::StorageMaterializedView::supportsTransactions() const @ 0x000000003875dce3 9. ./build_docker/./src/Interpreters/IInterpreter.cpp:44: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b1f62 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:15:23.549396 [ 6070 ] {8823656a-0c89-42c8-8bed-72917ec75226} DynamicQueryHandler: Code: 60. DB::Exception: Table test_brpgomjs.target_table does not exist. Maybe you meant test_1.right_table?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:775: DB::StorageMaterializedView::getTargetTable() const @ 0x000000003873c740 8. ./src/Storages/StorageMaterializedView.h:38: DB::StorageMaterializedView::supportsTransactions() const @ 0x000000003875dce3 9. ./build_docker/./src/Interpreters/IInterpreter.cpp:44: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b1f62 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a67b26 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:23.947627 [ 16230 ] {c593b13e-d52b-4c71-a1ab-7d3806ac1976} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41936) (comment: 00700_decimal_complex_types.sql) (query 124, line 162) (in query: SELECT number % 2 ? toDecimal32('32.1', 5) : toDecimal64('64.2', 2) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000030c0ce59 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309c5237 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d1c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:23.953298 [ 16230 ] {} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000030c0ce59 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309c5237 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d1c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:24.218101 [ 3618 ] {} test_7.rmt1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003a3dfd6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003d179be4 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1789: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003d1613c2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1297: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160a3b 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1507: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x000000003d16cc4d 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1241: zkutil::ZooKeeper::asyncTryGetNoThrow(String const&, std::shared_ptr>) @ 0x000000003d006e46 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:606: zkutil::ZooKeeper::getImpl(String const&, String&, Coordination::Stat*, std::shared_ptr>) @ 0x000000003d005c95 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:627: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003d008289 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:665: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003d0075d3 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:284: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a238e4e 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a234405 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a230a02 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a25a2bf 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 16. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:25.138019 [ 16230 ] {be5ac65b-4a49-4546-8a5e-19e34fbcf940} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41936) (comment: 00700_decimal_complex_types.sql) (query 125, line 163) (in query: SELECT number % 2 ? toDecimal32('32.1', 5) : toDecimal128('128.2', 3) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>>(std::vector> const&) @ 0x0000000030c0e539 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309c5e69 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d1c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:25.153813 [ 16230 ] {} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>>(std::vector> const&) @ 0x0000000030c0e539 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309c5e69 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d1c 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:25.174316 [ 17228 ] {9a472c03-5c95-4944-b48f-661d3f6bf916} executeQuery: Code: 46. DB::Exception: Unknown table function pv123. (UNKNOWN_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41868) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: SELECT Price FROM pv123(price=20)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:25.207128 [ 17228 ] {} TCPHandler: Code: 46. DB::Exception: Unknown table function pv123. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:26.556695 [ 16230 ] {a6779b08-7ccb-4c13-b015-10fadad7b4a8} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41936) (comment: 00700_decimal_complex_types.sql) (query 126, line 165) (in query: SELECT number % 2 ? toDecimal64('64.1', 5) : toDecimal32('32.2', 1) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000030c13479 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309e9100 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d95 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:26.561990 [ 16230 ] {} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000030c13479 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309e9100 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d95 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:26.891498 [ 16207 ] {348294aa-eef4-487d-a084-7eed9d8a35ac} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nothing, should be a number: In scope SELECT arrayAUCPR([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 42, line 52) (in query: -- general negative tests select arrayAUCPR([], []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c4b47 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:26.959365 [ 16207 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nothing, should be a number: In scope SELECT arrayAUCPR([], []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c4b47 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:27.262131 [ 16691 ] {477841ba-9669-4d48-9dd9-89292326172d} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1045.96968 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49250) (comment: 02293_http_header_full_summary_without_progress.sh) (in query: SELECT 1 + sleepEachRow(0.00002) FROM numbers(100000) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:15:27.299997 [ 16691 ] {477841ba-9669-4d48-9dd9-89292326172d} DynamicQueryHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1045.96968 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:27.438885 [ 16354 ] {e9d8925f-455d-420a-88f6-c9534f55d701} executeQuery: Code: 46. DB::Exception: Unknown table function test_02428_v1. (UNKNOWN_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42018) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: SELECT Price FROM test_02428_v1(price=10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:27.451232 [ 16354 ] {} TCPHandler: Code: 46. DB::Exception: Unknown table function test_02428_v1. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:28.083653 [ 16230 ] {031967c6-1152-445e-986e-97c729846a6a} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41936) (comment: 00700_decimal_complex_types.sql) (query 127, line 166) (in query: SELECT number % 2 ? toDecimal64('64.1', 5) : toDecimal64('64.2', 2) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000030c14b99 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309e7d60 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d95 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:28.087987 [ 16230 ] {} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>(std::vector> const&) @ 0x0000000030c14b99 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309e7d60 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d95 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:28.460140 [ 16207 ] {a4c54d13-c9bc-41a9-ae03-8ddb892f5676} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 1, should be 2 or 3: In scope SELECT arrayAUCPR([0, 0, 1, 1]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 43, line 54) (in query: select arrayAUCPR([0, 0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000001b2bef37 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c48f3 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:28.482108 [ 16207 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 1, should be 2 or 3: In scope SELECT arrayAUCPR([0, 0, 1, 1]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000001b2bef37 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c48f3 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:28.507320 [ 16889 ] {673867ca-0ef1-46b8-bcf8-a8fdf490cc3a} executeQuery: Code: 36. DB::Exception: Tables have different secondary indices. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41988) (comment: 02888_attach_partition_from_different_tables.sql) (query 4, line 20) (in query: ALTER TABLE attach_partition_t2 ATTACH PARTITION tuple() FROM attach_partition_t1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7811: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0ca5a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7822: DB::MergeTreeData::checkStructureAndGetMergeTreeData(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0e23f 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a51dc57 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5806: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000399a5d03 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032992221 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:28.512206 [ 16889 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different secondary indices. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7811: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0ca5a 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7822: DB::MergeTreeData::checkStructureAndGetMergeTreeData(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0e23f 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a51dc57 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5806: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000399a5d03 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032992221 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:29.664932 [ 16230 ] {c4c26582-c0de-4cae-9141-cb7c1062736d} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41936) (comment: 00700_decimal_complex_types.sql) (query 128, line 167) (in query: SELECT number % 2 ? toDecimal64('64.1', 5) : toDecimal128('128.2', 3) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>>(std::vector> const&) @ 0x0000000030c16279 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309e843e 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d95 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:29.670747 [ 16230 ] {} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale, DB::Decimal>>(std::vector> const&) @ 0x0000000030c16279 5. bool DB::callOnBasicType, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x00000000309e843e 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8d95 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:30.048589 [ 16207 ] {c46b9dc5-59ea-42cf-bfcb-1c84d319dad7} executeQuery: Code: 36. DB::Exception: First two arguments for function arrayAUCPR must be Arrays of equal sizes: In scope SELECT arrayAUCPR([0.1, 0.35], [0, 0, 1, 1]). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 44, line 55) (in query: select arrayAUCPR([0.1, 0.35], [0, 0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b2c2d36 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:15:30.059692 [ 16207 ] {} TCPHandler: Code: 36. DB::Exception: First two arguments for function arrayAUCPR must be Arrays of equal sizes: In scope SELECT arrayAUCPR([0.1, 0.35], [0, 0, 1, 1]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b2c2d36 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:15:30.687651 [ 16889 ] {ed0fefbe-c1e8-4c84-888e-57b64723440f} executeQuery: Code: 36. DB::Exception: Tables have different projections. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41988) (comment: 02888_attach_partition_from_different_tables.sql) (query 8, line 53) (in query: ALTER TABLE attach_partition_t4 ATTACH PARTITION tuple() FROM attach_partition_t3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7814: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0cba2 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7822: DB::MergeTreeData::checkStructureAndGetMergeTreeData(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0e23f 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a51dc57 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5806: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000399a5d03 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032992221 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:30.714413 [ 18722 ] {db207125-1c3e-4e9b-903d-0d55c43b18f9} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37852) (comment: 02200_use_skip_indexes.sql) (query 3, line 12) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_13`.`data_02200` AS `__table1` WHERE `__table1`.`value` = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:30.720600 [ 18722 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:30.721052 [ 18403 ] {3b5b4f8b-d56d-4b34-bd95-f080e810387d} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46666) (comment: 02200_use_skip_indexes.sql) (query 3, line 12) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value` FROM `test_13`.`data_02200` AS `__table1` WHERE `__table1`.`value` = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:30.726311 [ 18403 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:30.729317 [ 18149 ] {7b5a8a4c-8be8-41cc-94e6-8a17142fdfda} executeQuery: Code: 158. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 : While executing Remote. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42126) (comment: 02200_use_skip_indexes.sql) (query 3, line 12) (in query: -- { echoOn } SELECT * FROM data_02200 WHERE value = 1 SETTINGS use_skip_indexes=1, max_rows_to_read=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:15:30.733885 [ 16889 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different projections. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7814: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0cba2 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7822: DB::MergeTreeData::checkStructureAndGetMergeTreeData(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0e23f 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a51dc57 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5806: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000399a5d03 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032992221 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:30.741962 [ 18149 ] {} TCPHandler: Code: 158. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 10.00. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 : While executing Remote. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:31.002058 [ 16230 ] {49e47dd4-0b0d-42ce-9b43-5d9045bfc487} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41936) (comment: 00700_decimal_complex_types.sql) (query 129, line 169) (in query: SELECT number % 2 ? toDecimal128('128.1', 5) : toDecimal32('32.2', 1) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>(std::vector> const&) @ 0x0000000030c1b1b9 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000030a0c78a 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8c88 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:31.007095 [ 16230 ] {} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>(std::vector> const&) @ 0x0000000030c1b1b9 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000030a0c78a 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8c88 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:31.308794 [ 6028 ] {a8aad18a-23c0-49eb-a7bd-7b8f347ed7f3} executeQuery: Code: 456. DB::Exception: Substitution `quantity` is not set. (UNKNOWN_QUERY_PARAMETER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42156) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: SELECT Price FROM test_02428_pv2(price=50)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:71: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x00000000337e96fc 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:80: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000337e52ee 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:39: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e471a 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 11. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 13. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 15. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 16. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 17. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 18. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 19. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 20. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 21. ./build_docker/./src/Storages/StorageView.cpp:236: DB::StorageView::replaceQueryParametersIfParametrizedView(std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x0000000038eacbfd 22. ./build_docker/./src/Interpreters/Context.cpp:2522: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000317e6a0e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4724: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030423935 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:15:31.317044 [ 6028 ] {} TCPHandler: Code: 456. DB::Exception: Substitution `quantity` is not set. (UNKNOWN_QUERY_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:71: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x00000000337e96fc 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:80: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000337e52ee 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:39: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e471a 7. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 9. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 11. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 13. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 15. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 16. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 17. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 18. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 19. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:57: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000337e90d2 20. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000337e492a 21. ./build_docker/./src/Storages/StorageView.cpp:236: DB::StorageView::replaceQueryParametersIfParametrizedView(std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x0000000038eacbfd 22. ./build_docker/./src/Interpreters/Context.cpp:2522: DB::Context::buildParametrizedViewStorage(String const&, String const&, std::unordered_map, std::equal_to, std::allocator>> const&) @ 0x00000000317e6a0e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4724: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030423935 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:15:31.604566 [ 16207 ] {b0330847-83ae-42f2-8acf-c00ec93e2d9a} executeQuery: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayAUCPR is of type Nothing, should be a number or Enum: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 45, line 56) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c4fd5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:31.610749 [ 16207 ] {} TCPHandler: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayAUCPR is of type Nothing, should be a number or Enum: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c4fd5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:31.643817 [ 16207 ] {2612215d-ee36-4a2a-bd54-a629aeefa1ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 4, should be 2 or 3: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, 0], [1, 1, 0, 1]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 46, line 57) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, 0], [1, 1, 0, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000001b2bef37 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c48f3 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:31.648912 [ 16207 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUCPR doesn't match: passed 4, should be 2 or 3: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, 0], [1, 1, 0, 1]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000001b2bef37 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c48f3 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:31.682668 [ 16207 ] {bee71c71-2440-4a8d-a9b8-49a141b3a92c} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type String, should be a number: In scope SELECT arrayAUCPR(['a', 'b', 'c', 'd'], [1, 0, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 47, line 58) (in query: select arrayAUCPR(['a', 'b', 'c', 'd'], [1, 0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c4b47 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:31.688216 [ 16207 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type String, should be a number: In scope SELECT arrayAUCPR(['a', 'b', 'c', 'd'], [1, 0, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c4b47 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:31.718836 [ 16207 ] {cbb0c7b0-20ff-4f5e-acf6-4e188f3ac5cb} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nullable(Float64), should be a number: In scope SELECT arrayAUCPR([0.1, 0.4, NULL, 0.8], [0, 0, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 48, line 59) (in query: select arrayAUCPR([0.1, 0.4, NULL, 0.8], [0, 0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c4b47 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:31.723342 [ 16207 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nullable(Float64), should be a number: In scope SELECT arrayAUCPR([0.1, 0.4, NULL, 0.8], [0, 0, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c4b47 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:31.753057 [ 16207 ] {a2211f06-a474-400e-b91b-cc3111c1695b} executeQuery: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayAUCPR is of type Nullable(UInt8), should be a number or Enum: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, NULL, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 49, line 60) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, NULL, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c4fd5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:31.793642 [ 16207 ] {} TCPHandler: Code: 43. DB::Exception: Second argument (arr_labels) for function arrayAUCPR is of type Nullable(UInt8), should be a number or Enum: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, NULL, 1, 1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c4fd5 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:32.730316 [ 16230 ] {d5f6117d-3fa7-4247-9853-4865c2022f65} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41936) (comment: 00700_decimal_complex_types.sql) (query 130, line 170) (in query: SELECT number % 2 ? toDecimal128('128.1', 5) : toDecimal64('64.2', 2) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>(std::vector> const&) @ 0x0000000030c1c899 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000030a0ba00 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8c88 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:32.736199 [ 16230 ] {} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>(std::vector> const&) @ 0x0000000030c1c899 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000030a0ba00 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8c88 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:33.104707 [ 18149 ] {b1b99e20-e8c3-4517-9a30-c722f4b75b4f} executeQuery: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: x . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47270) (comment: 02369_analyzer_array_join_function.sql) (query 13, line 25) (in query: SELECT arrayMap(x -> arrayJoin(x), [[1, 2, 3]]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000030316776 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000003031084b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x00000000302fbf8d 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003033933a 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:378: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000032d3187d 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf81cf 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:33.110373 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: x . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000030316776 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000003031084b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x00000000302fbf8d 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003033933a 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:378: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000032d3187d 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf81cf 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:33.160851 [ 18149 ] {4fb30fec-b94f-4064-a16f-192468e9f918} executeQuery: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: CAST(x, 'Array(UInt8)'_String) . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47270) (comment: 02369_analyzer_array_join_function.sql) (query 14, line 27) (in query: SELECT arrayMap(x -> arrayJoin(cast(x, 'Array(UInt8)')), [[1, 2, 3]]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000030316776 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000003031084b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x00000000302fbf8d 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003033933a 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:378: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000032d3187d 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf81cf 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:33.165753 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: CAST(x, 'Array(UInt8)'_String) . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000030316776 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000003031084b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x00000000302fbf8d 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003033933a 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:378: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000032d3187d 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf81cf 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:33.618270 [ 16207 ] {345af48a-14b1-4602-99cb-65c16e4dd3e6} executeQuery: Code: 43. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR is of type Nullable(UInt8), should be integer: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 50, line 62) (in query: -- negative tests for optional argument select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, NULL]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000001b2bf337 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c5274 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:33.622935 [ 16207 ] {} TCPHandler: Code: 43. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR is of type Nullable(UInt8), should be integer: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 0, NULL]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000001b2bf337 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c5274 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:33.654821 [ 16207 ] {8b53aa6e-6bdd-4ef1-9c53-f3bd548d3d54} executeQuery: Code: 43. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR is of type String, should be integer: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], ['a', 'b', 'c']). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 51, line 64) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], ['a', 'b', 'c']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000001b2bf337 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c5274 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:33.659757 [ 16207 ] {} TCPHandler: Code: 43. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR is of type String, should be integer: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], ['a', 'b', 'c']). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000001b2bf337 4. DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000001b2c5274 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:34.066346 [ 16702 ] {d0f7bb5c-d270-460e-9bb2-783f703da885} DynamicQueryHandler: Code: 271. DB::Exception: Cannot decompress, the number of elements in the compressed data (65) is not equal to the expected number of elements in the decompressed data (1). (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. ./build_docker/./src/Compression/CompressionCodecT64.cpp:589: DB::CompressionCodecT64::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000003ddbc43b 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000003de7e2f3 6. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:329: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x000000003dd31179 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:24: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x000000003dd2b846 8. DB::ReadBuffer::next() @ 0x0000000008ef7cef 9. ./build_docker/./src/IO/ReadBuffer.cpp:34: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000001f961366 10. DB::ReadBuffer::next() @ 0x0000000008ef7cef 11. ./src/IO/ReadBuffer.h:96: DB::ConcatReadBuffer::nextImpl() @ 0x00000000316a2ab7 12. DB::ReadBuffer::next() @ 0x0000000008ef7cef 13. ./src/IO/ReadBuffer.h:81: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003383f5fa 14. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 15. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:34.092923 [ 16230 ] {e7fbb79b-4964-4f34-8f20-e043b9f5dac2} executeQuery: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41936) (comment: 00700_decimal_complex_types.sql) (query 131, line 171) (in query: SELECT number % 2 ? toDecimal128('128.1', 5) : toDecimal128('128.2', 3) FROM system.numbers LIMIT 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>>(std::vector> const&) @ 0x0000000030c1dfb9 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000030a0c3b5 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8c88 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:34.099014 [ 16230 ] {} TCPHandler: Code: 48. DB::Exception: Conditional functions with different Decimal scales. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. unsigned int DB::(anonymous namespace)::FunctionIf::decimalScale>, DB::Decimal>>(std::vector> const&) @ 0x0000000030c1dfb9 5. bool DB::callOnBasicType>, true, true, true, false, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&>(DB::TypeIndex, DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)&) @ 0x0000000030a0c3b5 6. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000306b8c88 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 13. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 17. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 18. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:34.161315 [ 6028 ] {3bb9cc38-84a7-4fc5-85d7-6151aa4a0ca1} executeQuery: Code: 47. DB::Exception: JOIN ALL RIGHT JOIN ... USING (s) using identifier 's' cannot be resolved from left table expression. In scope SELECT count() FROM (SELECT [1], count(1)) AS t1 ALL RIGHT JOIN (SELECT number AS s FROM numbers(2)) AS t2 USING (s). (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47288) (comment: 01010_pm_join_all_join_bug.sql) (query 9, line 13) (in query: SELECT count() FROM ( SELECT [1], count(1) ) AS t1 ALL RIGHT JOIN ( SELECT number AS s FROM numbers(2) ) AS t2 USING (s);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000304cd95f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5279: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304c447a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5381: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7826 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:34.167222 [ 6028 ] {} TCPHandler: Code: 47. DB::Exception: JOIN ALL RIGHT JOIN ... USING (s) using identifier 's' cannot be resolved from left table expression. In scope SELECT count() FROM (SELECT [1], count(1)) AS t1 ALL RIGHT JOIN (SELECT number AS s FROM numbers(2)) AS t2 USING (s). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000304cd95f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5279: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304c447a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5381: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7826 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:35.048873 [ 17390 ] {2706b86b-4ed1-4b87-9b1f-b3559115662b} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47380) (comment: 01662_join_mixed.sql) (query 1, line 1) (in query: select * from (select 'a' as a, 'b' as b, 42 as forty_two) as t1 inner join (select 'a' as a, 'b' as b, 42 as forty_two) as t2 on t1.b = t2.a or t1.forty_two = t2.forty_two;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cecf2f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:15:35.061387 [ 17390 ] {} TCPHandler: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1276: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cecf2f 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:15:35.398208 [ 6028 ] {3f3f07e9-2c2f-43fc-ae34-0d69af5d3f3c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=850). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47384) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: SELECT Price FROM test_02428_pv4(price=10) ORDER BY Price), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:15:35.413071 [ 6028 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=850). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:15:35.679260 [ 16207 ] {4a1582e6-e80d-45cd-aede-b57d59feed97} executeQuery: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 1, 0, 0]). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 52, line 65) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 1, 0, 0]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000001b2b5677 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b2c2f6d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:15:35.683233 [ 16207 ] {} TCPHandler: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, 1, 0, 0]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000001b2b5677 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b2c2f6d 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:15:37.266523 [ 16207 ] {b6b485b8-0bba-4504-b3b0-e9f26cf84225} executeQuery: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must not contain negative values: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, -1, 0]). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 53, line 66) (in query: select arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, -1, 0]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000001b2b58ad 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b2c20bb 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:15:37.271812 [ 16207 ] {} TCPHandler: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must not contain negative values: In scope SELECT arrayAUCPR([0.1, 0.4, 0.35, 0.8], [0, 0, 1, 1], [0, -1, 0]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000001b2b58ad 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b2c20bb 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:15:37.994805 [ 6028 ] {80411f71-d7b9-4190-afc8-89e6a88c8749} executeQuery: Code: 714. DB::Exception: `cluster_for_parallel_replicas` setting refers to cluster with 2 shards. Expected a cluster with one shard. (UNEXPECTED_CLUSTER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47432) (comment: 02982_parallel_replicas_unexpected_cluster.sql) (query 6, line 8) (in query: SELECT count() FROM test_unexpected_cluster WHERE NOT ignore(*);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000cd8388a 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:852: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x000000003704549f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:992: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67326 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:38.004010 [ 6028 ] {} TCPHandler: Code: 714. DB::Exception: `cluster_for_parallel_replicas` setting refers to cluster with 2 shards. Expected a cluster with one shard. (UNEXPECTED_CLUSTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x000000000cd8388a 4. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:852: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x000000003704549f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:992: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67326 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:38.749211 [ 16207 ] {79a0cc33-122c-44aa-848b-c2b2264d92ae} executeQuery: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: while executing 'FUNCTION arrayAUCPR(__table1.x :: 2, __table1.y :: 3, __table1.z :: 4) -> arrayAUCPR(__table1.x, __table1.y, __table1.z) Float64 : 1'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 54, line 67) (in query: select arrayAUCPR(x, y, z) from ( select [1] as x, [0] as y, [0, 0, 0, 0, 0, 0] as z UNION ALL select [1] as x, [0] as y, [] as z );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000001b2b5677 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b2c2f6d 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:38.760233 [ 16207 ] {} TCPHandler: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: while executing 'FUNCTION arrayAUCPR(__table1.x :: 2, __table1.y :: 3, __table1.z :: 4) -> arrayAUCPR(__table1.x, __table1.y, __table1.z) Float64 : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000001b2b5677 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b2c2f6d 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:38.868480 [ 16207 ] {6c3ccfcb-ce74-4fe4-93b1-57ebc72561cc} executeQuery: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: while executing 'FUNCTION arrayAUCPR(__table1.x :: 3, __table1.y :: 1, __table1.z :: 2) -> arrayAUCPR(__table1.x, __table1.y, __table1.z) Float64 : 4'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42360) (comment: 03272_arrayAUCPR.sql) (query 55, line 72) (in query: select arrayAUCPR(x, y, z) from ( select [1] as x, [0] as y, [0, 0] as z UNION ALL select [1] as x, [1] as y, [0, 0, 0, 0] as z );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000001b2b5677 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b2c2f6d 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:38.877570 [ 16207 ] {} TCPHandler: Code: 36. DB::Exception: Third argument (arr_partial_offsets) for function arrayAUCPR must contain Arrays of size 3: while executing 'FUNCTION arrayAUCPR(__table1.x :: 3, __table1.y :: 1, __table1.z :: 2) -> arrayAUCPR(__table1.x, __table1.y, __table1.z) Float64 : 4'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000001b2b5677 4. DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001b2c2f6d 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:39.098202 [ 16235 ] {d9cc9679-3e63-4e23-954a-54b194f2b783} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 0.00 B (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47552) (comment: 02845_group_by_constant_keys.sql) (query 2, line 2) (in query: select count(number), 1 AS k1, 2 as k2, 3 as k3 from numbers_mt(10000000) group by k1, k2, k3 settings optimize_group_by_constant_keys=1, enable_software_prefetch_in_aggregation=1, compile_aggregate_expressions = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:39.117714 [ 16235 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 0.00 B (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:39.122729 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d89d0f01-a97e-4c73-b86d-28f26ac45e49::all_1_26_5}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001f85446d 4. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000001f84c969 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:146: CurrentMemoryTracker::injectFault() @ 0x000000001f62af1f 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:269: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000001f8efcd5 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a57ca6b 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a57949e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:41.637055 [ 16352 ] {43455a9a-b05a-4220-8c92-72baaaf1ed88} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46412) (comment: 00999_join_on_expression.sql) (in query: DROP DATABASE IF EXISTS test_bqaw97jv SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:41.641037 [ 16352 ] {43455a9a-b05a-4220-8c92-72baaaf1ed88} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:41.895414 [ 16446 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:41.896110 [ 16446 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:41.974274 [ 16446 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:41.980222 [ 6078 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:41.990276 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 9 entries up to offset 975: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:42.053631 [ 16446 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:42.054326 [ 16446 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:42.746122 [ 16446 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:42.746830 [ 16446 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:42.785283 [ 2998 ] {0956741d-774f-4a11-8c2b-d82fc0243101} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57924) (comment: 01223_dist_on_dist.sql) (query 38, line 51) (in query: SELECT `__table1`.`key` AS `key` FROM `test_fdecy66j`.`dist_layer_01223` AS `__table1` GROUP BY `__table1`.`key` ORDER BY `__table1`.`key` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003ab4ec00 15. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003ab2c32a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f2afe36 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f2923e7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 19. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:15:42.792680 [ 16323 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59172, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:42.793184 [ 16323 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59172, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:42.803371 [ 2998 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003ab4ec00 15. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003ab2c32a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f2afe36 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f2923e7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 19. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:42.836426 [ 17228 ] {392e870d-f99c-4938-8ce5-b99c80c4d87a} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003ab4ec00 15. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003ab2c32a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f2afe36 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f2923e7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 19. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47262) (comment: 01223_dist_on_dist.sql) (query 38, line 51) (in query: select * from dist_01223 group by key order by key settings distributed_aggregation_memory_efficient=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:15:42.901032 [ 18131 ] {3b88c330-ed15-474e-af35-d47b5d090ad7} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37140) (comment: 01223_dist_on_dist.sql) (query 38, line 51) (in query: SELECT `__table1`.`key` AS `key` FROM `test_fdecy66j`.`dist_layer_01223` AS `__table1` GROUP BY `__table1`.`key` ORDER BY `__table1`.`key` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003ab4ec00 15. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003ab2c32a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f2afe36 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f2923e7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 19. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:15:42.907745 [ 16355 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59180, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:42.908323 [ 16355 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59180, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:42.926640 [ 17228 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003ab4ec00 15. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003ab2c32a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f2afe36 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f2923e7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 19. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:43.201340 [ 16446 ] {ec727d5a-6c6d-45ae-abb9-bab8b17b01b3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46456) (comment: 01223_dist_on_dist.sql) (in query: DROP DATABASE IF EXISTS test_fdecy66j SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:43.205452 [ 16446 ] {ec727d5a-6c6d-45ae-abb9-bab8b17b01b3} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:43.296659 [ 6078 ] {68321052-460a-4aa2-9d4f-7c0d1d42b7da} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46472) (comment: 01223_dist_on_dist.sql) (in query: DROP DATABASE IF EXISTS test_fdecy66j SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:43.303875 [ 6078 ] {68321052-460a-4aa2-9d4f-7c0d1d42b7da} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:43.513352 [ 18131 ] {3b88c330-ed15-474e-af35-d47b5d090ad7} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:37140). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003aecc107 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000003aea56e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:43.519524 [ 18131 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003ab4ec00 15. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003ab2c32a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f2afe36 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f2923e7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 19. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:43.630582 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 2840 entries up to offset 273947: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 4.17 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:44.296075 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:44.296713 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:44.454047 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:44.480435 [ 6078 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:44.554204 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:44.573207 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:44.980536 [ 19243 ] {dc7595d7-75fa-4d82-8cd7-57bfbeecec3b} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.99 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42206) (comment: 02585_query_status_deadlock.sh) (query 2, line 3) (in query: SELECT `__table1`.`number` AS `number` FROM `system`.`numbers_mt` AS `__table1` WHERE `__table1`.`number` IN (SELECT `__table1`.`number` AS `number` FROM `tmp` AS `__table1`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003b0c9858 15. ./build_docker/./src/Server/TCPHandler.cpp:2235: DB::TCPHandler::processData(DB::QueryState&, bool) @ 0x000000003aef1294 16. ./build_docker/./src/Server/TCPHandler.cpp:985: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x000000003aeedbd7 17. ./build_docker/./src/Server/TCPHandler.cpp:1018: DB::TCPHandler::readTemporaryTables(DB::QueryState&) @ 0x000000003aef5bfb 18. ./build_docker/./src/Server/TCPHandler.cpp:555: void std::__function::__policy_invoker)>::__call_impl[abi:ne190107])>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000003af0d73b 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000318436f6 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1185: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033828b0b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:45.059105 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:45.059894 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:45.692311 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_73_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.18 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:45.693689 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_73_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.18 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:45.856285 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 1981 entries up to offset 121555: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 4.16 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:46.028749 [ 6078 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:46.029456 [ 6078 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:46.056077 [ 16199 ] {80215036-3325-40d5-be69-49f5b2695765} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47942) (comment: 00700_decimal_in_keys.sql) (query 3, line 13) (in query: INSERT INTO decimal (d1, d2, d3) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:15:46.066168 [ 16199 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:15:46.186482 [ 16693 ] {60af77b3-b1c0-4027-9b1d-d8c9604e7ea0} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42104) (comment: 00871_t64_codec_signed.sql) (query 52, line 70) (in query: INSERT INTO t64 SELECT (1 - toInt64(intExp2(32)) + number) AS x, x, x, x, x, x, x, x FROM numbers(65);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 2025.11.13 09:15:46.219727 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:46.220336 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:46.253036 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:46.253709 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:46.260764 [ 16235 ] {e6f8eb38-25f3-46ee-b2fc-00c63f6ebf4e} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47924) (comment: 03022_alter_materialized_view_query_has_inner_table.sql) (query 5, line 7) (in query: INSERT INTO src_table (a, b) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:15:46.265250 [ 16693 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:15:46.284663 [ 16235 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:15:46.293616 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:46.294202 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:46.312796 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.66 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:46.929205 [ 19619 ] {734bc2ce-6563-4218-a329-7ca70911014e} executeQuery: Code: 57. DB::Exception: Table test_ujaxxg4x.mult_tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00564_versioned_collapsing_merge_tree.sql) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_ujaxxg4x.mult_tab UUID '57b5c996-bca5-4b23-8f39-eb55897e607f' (`date` Date, `value` String, `version` UInt64, `sign` Int8) ENGINE = VersionedCollapsingMergeTree(date, (date, value), 8192, sign, version)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:46.941728 [ 19619 ] {734bc2ce-6563-4218-a329-7ca70911014e} executeQuery: Code: 57. DB::Exception: Table test_ujaxxg4x.mult_tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47964) (comment: 00564_versioned_collapsing_merge_tree.sql) (query 15, line 20) (in query: create table mult_tab (date Date, value String, version UInt64, sign Int8) engine = VersionedCollapsingMergeTree(date, (date, value), 8192, sign, version);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:46.955647 [ 19619 ] {} TCPHandler: Code: 57. DB::Exception: Table test_ujaxxg4x.mult_tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:47.185708 [ 6078 ] {3c271b14-a06b-4815-93a9-5253906ce384} executeQuery: Code: 46. DB::Exception: Unknown table function test_02428_pv5. (UNKNOWN_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48094) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: SELECT Price FROM test_02428_pv5(price=30, quantity=8, limit=1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:47.198781 [ 6078 ] {} TCPHandler: Code: 46. DB::Exception: Unknown table function test_02428_pv5. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:47.937041 [ 19619 ] {f5aca3f3-0afc-4241-988e-0a876917f3ea} executeQuery: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_group_by should be >= 0 and < 1 (-0.1). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48086) (comment: 03270_max_bytes_ratio_before_external_group_by.sql) (query 1, line 1) (in query: SELECT uniqExact(number::String) FROM numbers(10e6) GROUP BY (number%100)::String FORMAT Null SETTINGS max_bytes_ratio_before_external_group_by=-0.1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000001ab169ca 4. ./build_docker/./src/Interpreters/Aggregator.cpp:239: DB::Aggregator::Params::getMaxBytesBeforeExternalGroupBy(unsigned long, double) @ 0x0000000031c9cffc 5. ./build_docker/./src/Planner/Planner.cpp:446: DB::(anonymous namespace)::getAggregatorParams(std::shared_ptr const&, DB::AggregationAnalysisResult const&, DB::(anonymous namespace)::QueryAnalysisResult const&, DB::SelectQueryInfo const&, bool) @ 0x0000000032c154d3 6. ./build_docker/./src/Planner/Planner.cpp:483: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf8f22 7. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:15:47.941481 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_73_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.18 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:47.944681 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:47.945344 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:47.946860 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_73_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.18 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:47.950245 [ 19619 ] {} TCPHandler: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_group_by should be >= 0 and < 1 (-0.1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000001ab169ca 4. ./build_docker/./src/Interpreters/Aggregator.cpp:239: DB::Aggregator::Params::getMaxBytesBeforeExternalGroupBy(unsigned long, double) @ 0x0000000031c9cffc 5. ./build_docker/./src/Planner/Planner.cpp:446: DB::(anonymous namespace)::getAggregatorParams(std::shared_ptr const&, DB::AggregationAnalysisResult const&, DB::(anonymous namespace)::QueryAnalysisResult const&, DB::SelectQueryInfo const&, bool) @ 0x0000000032c154d3 6. ./build_docker/./src/Planner/Planner.cpp:483: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf8f22 7. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:15:48.067549 [ 19619 ] {a334522f-c411-4cf9-b691-19b7340b80e3} executeQuery: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_group_by should be >= 0 and < 1 (1). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48086) (comment: 03270_max_bytes_ratio_before_external_group_by.sql) (query 2, line 2) (in query: SELECT uniqExact(number::String) FROM numbers(10e6) GROUP BY (number%100)::String FORMAT Null SETTINGS max_bytes_ratio_before_external_group_by=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000001ab169ca 4. ./build_docker/./src/Interpreters/Aggregator.cpp:239: DB::Aggregator::Params::getMaxBytesBeforeExternalGroupBy(unsigned long, double) @ 0x0000000031c9cffc 5. ./build_docker/./src/Planner/Planner.cpp:446: DB::(anonymous namespace)::getAggregatorParams(std::shared_ptr const&, DB::AggregationAnalysisResult const&, DB::(anonymous namespace)::QueryAnalysisResult const&, DB::SelectQueryInfo const&, bool) @ 0x0000000032c154d3 6. ./build_docker/./src/Planner/Planner.cpp:483: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf8f22 7. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:15:48.074738 [ 19619 ] {} TCPHandler: Code: 36. DB::Exception: Setting max_bytes_ratio_before_external_group_by should be >= 0 and < 1 (1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, double&) @ 0x000000001ab169ca 4. ./build_docker/./src/Interpreters/Aggregator.cpp:239: DB::Aggregator::Params::getMaxBytesBeforeExternalGroupBy(unsigned long, double) @ 0x0000000031c9cffc 5. ./build_docker/./src/Planner/Planner.cpp:446: DB::(anonymous namespace)::getAggregatorParams(std::shared_ptr const&, DB::AggregationAnalysisResult const&, DB::(anonymous namespace)::QueryAnalysisResult const&, DB::SelectQueryInfo const&, bool) @ 0x0000000032c154d3 6. ./build_docker/./src/Planner/Planner.cpp:483: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf8f22 7. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:15:48.548203 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:48.548870 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:48.632218 [ 6072 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:48.819809 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:48.820472 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:48.922686 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.66 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:48.923582 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.66 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:48.985866 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_74_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 16.08 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:48.987559 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_74_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 16.08 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:49.020579 [ 6078 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:49.023604 [ 6078 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:49.031139 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 16.21 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:49.031828 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 16.21 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:49.150608 [ 19499 ] {4c428847-09e4-4370-bfee-49b4adbecfb4} executeQuery: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt8: In scope SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808)). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48090) (comment: 03003_arrayEnumerate_crash.sql) (query 1, line 1) (in query: SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x000000001ddf5c17 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x000000001ddf48d4 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x000000001de2ae91 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:15:49.170278 [ 19499 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt8: In scope SELECT arrayEnumerateUniqRanked(arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]]), materialize(1 AS x) OR toLowCardinality(-9223372036854775808)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x000000001ddf5c17 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x000000001ddf48d4 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x000000001de2ae91 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:15:49.216203 [ 19499 ] {31d0f9cd-3fa9-402d-9e57-17d78ab75921} executeQuery: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt64: In scope SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48090) (comment: 03003_arrayEnumerate_crash.sql) (query 2, line 2) (in query: SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x000000001ddf5c17 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x000000001ddf48d4 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x000000001de2ae91 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:15:49.221898 [ 19499 ] {} TCPHandler: Code: 36. DB::Exception: Incorrect argument 2 type of function arrayEnumerateUniqRanked. Expected an Array or Const(UInt64), got UInt64: In scope SELECT arrayEnumerateUniqRanked([[1, 2, 3], [2, 2, 1], [3]], number) FROM numbers(10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, char const*&, String&&) @ 0x000000001ddf5c17 4. DB::getArraysDepths(std::vector> const&, char const*) @ 0x000000001ddf48d4 5. DB::FunctionArrayEnumerateRankedExtended::getReturnTypeImpl(std::vector> const&) const @ 0x000000001de2ae91 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:15:49.522262 [ 19620 ] {5db15946-28e4-42b2-a898-c1e5aff007a7} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.82 GiB (attempt to allocate chunk of 145.94 MiB bytes), current RSS: 15.29 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION materialize(arrayMap(lambda(tuple(x), repeat('a', 50)), range(1000)) :: 1) -> materialize(arrayMap(lambda(tuple(x), repeat('a', 50)), range(1000))) Array(String) : 0'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48096) (comment: 02981_vertical_merges_memory_usage.sql) (query 3, line 16) (in query: INSERT INTO t_vertical_merge_memory SELECT number, arrayMap(x -> repeat('a', 50), range(1000)) FROM numbers(3000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnArray::replicateString(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370af00b 12. ./build_docker/./src/Columns/ColumnArray.cpp:1108: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370ae2c5 13. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x00000000371b3ac4 14. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x00000000371b7e0e 15. ./src/Functions/materialize.h:59: DB::FunctionMaterialize::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000302db4e0 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14f623 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:49.555677 [ 19620 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.82 GiB (attempt to allocate chunk of 145.94 MiB bytes), current RSS: 15.29 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION materialize(arrayMap(lambda(tuple(x), repeat('a', 50)), range(1000)) :: 1) -> materialize(arrayMap(lambda(tuple(x), repeat('a', 50)), range(1000))) Array(String) : 0'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnArray::replicateString(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370af00b 12. ./build_docker/./src/Columns/ColumnArray.cpp:1108: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370ae2c5 13. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x00000000371b3ac4 14. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x00000000371b7e0e 15. ./src/Functions/materialize.h:59: DB::FunctionMaterialize::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000302db4e0 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14f623 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:15:50.096866 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1349 entries up to offset 275296: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.68 GiB (attempt to allocate chunk of 4.25 MiB bytes), current RSS: 15.49 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 10. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 11. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 12. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 13. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 27. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 28. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x000000003335e7be 29. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba3381 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba31bf 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:50.351145 [ 17752 ] {b9ab16cf-a6cd-408b-b2ff-82d584293bac} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `count` in scope SELECT count. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48198) (comment: 03096_text_log_format_string_args_not_empty.sql) (query 2, line 3) (in query: select count;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:15:50.547634 [ 17752 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `count` in scope SELECT count. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:15:50.749926 [ 19194 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:50.756018 [ 19194 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:50.829072 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_74_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:50.830814 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_74_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:51.382871 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:51.383536 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:51.480832 [ 16199 ] {c77b67ba-ad7a-4e6c-9969-928075320702} executeQuery: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: x . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48186) (comment: 02369_analyzer_array_join_function.sql) (query 13, line 25) (in query: SELECT arrayMap(x -> arrayJoin(x), [[1, 2, 3]]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000030316776 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000003031084b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x00000000302fbf8d 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003033933a 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:378: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000032d3187d 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf81cf 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:51.486562 [ 16199 ] {} TCPHandler: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: x . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000030316776 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000003031084b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x00000000302fbf8d 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003033933a 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:378: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000032d3187d 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf81cf 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:51.621870 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:51.666547 [ 3728 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_1_39_7} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:51.667847 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_1_39_7}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:51.683129 [ 16199 ] {7248b949-83a1-48e6-924f-1f81a56cbeb0} executeQuery: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: CAST(x, 'Array(UInt8)'_String) . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48186) (comment: 02369_analyzer_array_join_function.sql) (query 14, line 27) (in query: SELECT arrayMap(x -> arrayJoin(cast(x, 'Array(UInt8)')), [[1, 2, 3]]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000030316776 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000003031084b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x00000000302fbf8d 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003033933a 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:378: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000032d3187d 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf81cf 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:51.688102 [ 16199 ] {} TCPHandler: Code: 36. DB::Exception: Expression in arrayJoin cannot depend on lambda argument: CAST(x, 'Array(UInt8)'_String) . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:1020: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000030316776 5. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:795: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x000000003031084b 6. ./build_docker/./src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x00000000302fbf8d 7. ./build_docker/./src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x000000003033933a 8. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:378: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000032d3187d 9. ./build_docker/./src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf81cf 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:15:51.794654 [ 17752 ] {46f8d4c6-76ae-4c54-946b-5eafc15ba69b} executeQuery: Code: 46. DB::Exception: Function with name `conut` does not exist. In scope SELECT conut(). Maybe you meant: ['concat','count']. (UNKNOWN_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48198) (comment: 03096_text_log_format_string_args_not_empty.sql) (query 3, line 5) (in query: select conut();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3352: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003047db55 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:15:51.798909 [ 17752 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `conut` does not exist. In scope SELECT conut(). Maybe you meant: ['concat','count']. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3352: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003047db55 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:15:51.833198 [ 16047 ] {12781895-244f-4ff7-98c4-44e837b19493} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 15.: In scope SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 1, line 1) (in query: -- MIN, MAX AND FAMILY should check for errors in its input SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1209: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x0000000022f3ff22 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022ee6e37 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:15:51.948160 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 15.: In scope SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1209: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x0000000022f3ff22 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022ee6e37 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:15:52.062236 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.065729 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.259900 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 7 entries up to offset 996: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.297865 [ 3732 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_1_39_7} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.299261 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_1_39_7}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.333677 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.334520 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.383763 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.384390 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.389796 [ 3739 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_74_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.391423 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_74_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.751690 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:52.875357 [ 16199 ] {ffec5452-af74-45ec-9a7d-b38e5a7d5e66} PushingToViews: Failed to push block to view test_3.mview (fbd20ead-0101-493c-aea4-7813d9130e39), Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_3.test_table 2025.11.13 09:15:53.069074 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:53.079799 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:53.112252 [ 16047 ] {ce196e15-7ce5-4253-9504-d8370b8756ce} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 65535.: In scope SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 2, line 3) (in query: SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1216: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x0000000022f3ff9d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022ee6e37 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:15:53.118096 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 65535.: In scope SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1216: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x0000000022f3ff9d 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:135: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000022ee6e37 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:15:53.191789 [ 19619 ] {1e2ba400-b420-4e52-b2e8-7d8bb9d2eba6} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.34 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION concat('string: '_String :: 2, toString(__table1.number) :: 1) -> concat('string: '_String, toString(__table1.number)) String : 0'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52966) (comment: 02122_parallel_formatting_JSONCompactEachRow.sh) (query 1, line 1) (in query: select number, number + 1, concat('string: ', toString(number)) from numbers(200000) format JSONCompactEachRow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::GatherUtils::concat, DB::GatherUtils::StringSource, DB::GatherUtils::StringSink>(DB::GatherUtils::ConstSource&&, DB::GatherUtils::StringSource&&, DB::GatherUtils::StringSink&&) @ 0x000000000d12efb9 12. DB::(anonymous namespace)::ConcatImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d11edcc 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:15:53.212526 [ 3903 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryLogElement]: Failed to flush system log system.query_log with 133 entries up to offset 35810: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 4.01 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037ae594e 10. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037d079ba 11. ./src/Columns/ColumnsCommon.h:125: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037af98a9 12. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037af962e 13. ./src/Columns/ColumnLowCardinality.h:140: DB::ColumnLowCardinality::index(DB::IColumn const&, unsigned long) const @ 0x00000000375d86c4 14. ./build_docker/./src/Columns/ColumnTuple.cpp:463: DB::ColumnTuple::index(DB::IColumn const&, unsigned long) const @ 0x000000003777b384 15. ./build_docker/./src/Columns/ColumnArray.cpp:959: COW::immutable_ptr DB::ColumnArray::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000370bbadb 16. ./src/Columns/ColumnsCommon.h:136: DB::ColumnArray::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000370ab628 17. ./build_docker/./src/Columns/ColumnMap.cpp:230: DB::ColumnMap::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000375e6715 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:47: DB::permuteBlockIfNeeded(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039829bfb 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:189: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba572d 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 31. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:53.215343 [ 19619 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.34 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION concat('string: '_String :: 2, toString(__table1.number) :: 1) -> concat('string: '_String, toString(__table1.number)) String : 0'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::GatherUtils::concat, DB::GatherUtils::StringSource, DB::GatherUtils::StringSink>(DB::GatherUtils::ConstSource&&, DB::GatherUtils::StringSource&&, DB::GatherUtils::StringSink&&) @ 0x000000000d12efb9 12. DB::(anonymous namespace)::ConcatImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d11edcc 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:53.552784 [ 3737 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_81_16} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:53.554158 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_81_16}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.046055 [ 16199 ] {ffec5452-af74-45ec-9a7d-b38e5a7d5e66} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_3.test_table. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48186) (comment: 02369_analyzer_array_join_function.sql) (query 20, line 43) (in query: INSERT INTO test_table VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdd406 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003bd5c011 15. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd699ce 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000032ad1b23 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ada2a3 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000032adffb3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:54.082744 [ 16397 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.72 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.083526 [ 16397 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.72 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.123760 [ 3725 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_48_67_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_48_63_3/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 9392): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.125368 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_48_67_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_48_63_3/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 9392): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.220921 [ 16199 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `n` in scope SELECT n, n * n AS n2 FROM test_3.test_table. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdd406 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:352: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003bd5c011 15. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd699ce 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000032ad1b23 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ada2a3 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000032adffb3 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:54.237441 [ 16397 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.830496 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.831250 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.842636 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.843340 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.884497 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_74_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.885048 [ 3732 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_1_39_7} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.72 GiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.885898 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_74_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.901274 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_1_39_7}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.72 GiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.941729 [ 3730 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_75_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.72 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column stat_mzxid): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_74_74_0/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 1020): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6f81ff 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:54.945619 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_75_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.72 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column stat_mzxid): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_74_74_0/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 1020): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6f81ff 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:55.089122 [ 16047 ] {44d3ee21-1163-45d9-923e-3ee2cd76c538} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: In scope SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)')). (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 4, line 9) (in query: -- aggThrow should check for errors in its input SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/ReadBuffer.cpp:55: DB::ReadBuffer::throwReadAfterEOF() @ 0x000000001f96068c 5. ./src/IO/ReadBuffer.h:165: DB::(anonymous namespace)::AggregateFunctionThrow::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025daa741 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:15:55.097017 [ 16047 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: In scope SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)')). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/ReadBuffer.cpp:55: DB::ReadBuffer::throwReadAfterEOF() @ 0x000000001f96068c 5. ./src/IO/ReadBuffer.h:165: DB::(anonymous namespace)::AggregateFunctionThrow::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025daa741 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:15:55.286378 [ 3727 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_34_40_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:55.287765 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_34_40_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:55.475764 [ 17268 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:55.476446 [ 17268 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:55.598239 [ 3735 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_34_40_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:55.599709 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_34_40_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:55.721894 [ 3731 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_75_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:55.729453 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_75_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.118928 [ 17268 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.119626 [ 17268 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.123481 [ 3734 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_48_67_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.125345 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_48_67_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.343946 [ 19194 ] {c996e7c0-7132-4742-a988-e31f9530ae35::all_1_2_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a4cd316 31. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e73d0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.368052 [ 19194 ] {ca8ed537-6215-46c9-b386-3860a6b9d2a2} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52958) (comment: 03280_json_subcolumns_in_primary_key_select_final.gen.sql) (query 13, line 20) (in query: optimize table test final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a4cd316 31. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e73d0 2025.11.13 09:15:56.390785 [ 19194 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a4cd316 31. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e73d0 2025.11.13 09:15:56.400974 [ 3730 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_34_40_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.402146 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_34_40_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.460572 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.584782 [ 16047 ] {d76bd056-55e3-4e4a-8790-3d84b4bf2f27} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 16. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 5, line 12) (in query: -- categoricalInformationValue should check for errors in its input SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:121: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025d9d2f5 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:15:56.589467 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 16. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:121: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025d9d2f5 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:15:56.754074 [ 3724 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_48_67_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.755357 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_48_67_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.767092 [ 17268 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.767678 [ 17268 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.795798 [ 3729 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_34_40_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.796974 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_34_40_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.867543 [ 3728 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_75_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:56.868950 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_75_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:57.064038 [ 19619 ] {5fb98019-d744-4cd8-ab6b-5287e6c24d43} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.33 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION toString(__table1.number : 3) -> toString(__table1.number) String : 1'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53022) (comment: 02122_parallel_formatting_JSONCompactEachRow.sh) (query 1, line 1) (in query: select number, number + 1, concat('string: ', toString(number)) from numbers(200000) format JSONCompactEachRow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./src/Functions/FunctionsConversion.h:1533: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf05fa 13. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde66b9 14. ./src/Core/callOnTypeIndex.h:255: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7efb 15. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 2025.11.13 09:15:57.086219 [ 16199 ] {65011b67-fd1d-4868-902b-cad0e6976112} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.27 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53074) (comment: 02346_fulltext_index_match_predicate.sql) (query 4, line 17) (in query: INSERT INTO tab VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:15:57.088060 [ 19619 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.33 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION toString(__table1.number : 3) -> toString(__table1.number) String : 1'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./src/Functions/FunctionsConversion.h:1533: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf05fa 13. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde66b9 14. ./src/Core/callOnTypeIndex.h:255: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7efb 15. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 22. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 23. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:57.115148 [ 16199 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.27 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:15:57.175743 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_74_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:57.177951 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_74_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:57.188464 [ 3912 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryMetricLogElement]: Failed to flush system log system.query_metric_log with 26 entries up to offset 3118: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000333e0dcc (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:57.545254 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:57.545896 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:57.577991 [ 16397 ] {b7827e40-83a3-42f9-a0d5-5645cbee48c3} executeQuery: Code: 46. DB::Exception: Unknown table function test_02428_pv11. (UNKNOWN_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53100) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: SELECT * FROM test_02428_pv11(price=10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:57.578562 [ 8203 ] {} test_odb1a8t8.test (c996e7c0-7132-4742-a988-e31f9530ae35): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.11.13 09:15:57.590213 [ 16397 ] {} TCPHandler: Code: 46. DB::Exception: Unknown table function test_02428_pv11. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:58.005067 [ 19243 ] {dc7595d7-75fa-4d82-8cd7-57bfbeecec3b} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.72 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003b0c9858 15. ./build_docker/./src/Server/TCPHandler.cpp:2298: DB::TCPHandler::processUnexpectedData() @ 0x000000003aedd7a0 16. ./build_docker/./src/Server/TCPHandler.cpp:983: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x000000003aeedbb4 17. ./build_docker/./src/Server/TCPHandler.cpp:1032: DB::TCPHandler::skipData(DB::QueryState&) @ 0x000000003aed663f 18. ./build_docker/./src/Server/TCPHandler.cpp:831: DB::TCPHandler::runImpl() @ 0x000000003aea5725 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:58.012106 [ 16047 ] {c24d1e40-a0ba-466f-9dcd-a36e2a1b3a14} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 31. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 6, line 15) (in query: SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:121: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025d9d2f5 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000266ac0aa 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:15:58.017556 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 31. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:121: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025d9d2f5 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000266ac0aa 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:15:58.069586 [ 19243 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.67 GiB (attempt to allocate chunk of 1.99 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003b0c9858 15. ./build_docker/./src/Server/TCPHandler.cpp:2235: DB::TCPHandler::processData(DB::QueryState&, bool) @ 0x000000003aef1294 16. ./build_docker/./src/Server/TCPHandler.cpp:985: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x000000003aeedbd7 17. ./build_docker/./src/Server/TCPHandler.cpp:1018: DB::TCPHandler::readTemporaryTables(DB::QueryState&) @ 0x000000003aef5bfb 18. ./build_docker/./src/Server/TCPHandler.cpp:555: void std::__function::__policy_invoker)>::__call_impl[abi:ne190107])>>(std::__function::__policy_storage const*, std::shared_ptr&&) @ 0x000000003af0d73b 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000318436f6 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1185: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033828b0b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:15:58.214042 [ 16390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:58.214685 [ 16390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:58.282667 [ 3732 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_48_67_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_48_63_3/data.bin (position: 494320, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 49fc80ccb85539cd4b2880255fc9962582dc930000dc760600): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_48_63_3/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 1 with max_rows_to_read = 11444): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:58.284160 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_48_67_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_48_63_3/data.bin (position: 494320, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 49fc80ccb85539cd4b2880255fc9962582dc930000dc760600): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_48_63_3/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 1 with max_rows_to_read = 11444): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:58.324613 [ 16215 ] {02beb460-b077-43c9-af29-8c6b8f9e2631} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.49 MiB bytes), current RSS: 15.27 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: (while reading column query): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_57_67_2/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 7144): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53032) (comment: 02585_query_status_deadlock.sh) (query 1, line 1) (in query: select query, event_time from system.query_log where query_id = 'test_5_test_02585_query_to_kill_id_1' and current_database = 'test_5' and query like 'select%' limit 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 2025.11.13 09:15:58.428144 [ 16215 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.49 MiB bytes), current RSS: 15.27 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: (while reading column query): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_57_67_2/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 7144): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:58.444575 [ 16390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:58.445460 [ 16390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.69 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:58.518752 [ 8203 ] {} DatabaseCatalog: Cannot drop table test_odb1a8t8.test (c996e7c0-7132-4742-a988-e31f9530ae35). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2953: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x00000000398e74a8 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2890: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x00000000398e4b55 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3296: DB::MergeTreeData::dropAllData() @ 0x000000003990124e 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:368: DB::StorageMergeTree::drop() @ 0x000000003a4a3553 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1443: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x0000000031b08d11 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1366: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031b2bec3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026d57d8a 14. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026d579ad 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026d576df 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:58.532403 [ 19618 ] {f00b6e59-f124-42e8-bfc3-15741b5d1144} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.27 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While reading or decompressing /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_57_67_2/query.bin (position: 109716, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 7c458ae926bff3715962f5b237edc0818284ac0100aa0c0c00): (while reading column query): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_57_67_2/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 7144): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47578) (comment: 01231_log_queries_min_type.sql) (query 8, line 12) (in query: select count() from system.query_log where current_database = currentDatabase() and query like 'select \'01231_log_queries_min_type/EXCEPTION_BEFORE_START%' and event_date >= yesterday();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 15. DB::ReadBuffer::next() @ 0x0000000008ef7cef 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 2025.11.13 09:15:58.547288 [ 18392 ] {40df221b-b474-41af-aed7-a4c4aa7cd679} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01710_projection_materialize_with_missing_columns.sql) (in query: /* ddl_entry=query-0000000005 */ ALTER TABLE test_x2uxhbo9.x (MATERIALIZE PROJECTION p_agg) SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationEntry.cpp:62: DB::MergeTreeMutationEntry::MergeTreeMutationEntry(DB::MutationCommands, std::shared_ptr, String const&, unsigned long, DB::TransactionID const&, DB::WriteSettings const&) @ 0x000000003a556e18 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:572: DB::StorageMergeTree::startMutation(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4a938d 19. ./build_docker/./src/Storages/StorageMergeTree.cpp:716: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b58bd 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 24. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 25. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 26. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 27. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 28. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 29. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:15:58.576800 [ 19618 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.27 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While reading or decompressing /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_57_67_2/query.bin (position: 109716, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 7c458ae926bff3715962f5b237edc0818284ac0100aa0c0c00): (while reading column query): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_57_67_2/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 7144): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 15. DB::ReadBuffer::next() @ 0x0000000008ef7cef 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:58.631646 [ 18392 ] {40df221b-b474-41af-aed7-a4c4aa7cd679} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52924) (comment: 01710_projection_materialize_with_missing_columns.sql) (query 6, line 7) (in query: alter table x materialize projection p_agg settings mutations_sync = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationEntry.cpp:62: DB::MergeTreeMutationEntry::MergeTreeMutationEntry(DB::MutationCommands, std::shared_ptr, String const&, unsigned long, DB::TransactionID const&, DB::WriteSettings const&) @ 0x000000003a556e18 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:572: DB::StorageMergeTree::startMutation(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4a938d 19. ./build_docker/./src/Storages/StorageMergeTree.cpp:716: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b58bd 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 24. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 25. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 26. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 27. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 28. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 29. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:15:58.671254 [ 18392 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationEntry.cpp:62: DB::MergeTreeMutationEntry::MergeTreeMutationEntry(DB::MutationCommands, std::shared_ptr, String const&, unsigned long, DB::TransactionID const&, DB::WriteSettings const&) @ 0x000000003a556e18 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:572: DB::StorageMergeTree::startMutation(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4a938d 19. ./build_docker/./src/Storages/StorageMergeTree.cpp:716: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b58bd 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 24. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 25. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 26. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 27. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 28. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d2ca 29. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:15:58.878312 [ 16690 ] {e209389a-258e-4a75-901b-5cbcb9d2c0ab} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50488) (comment: 01710_projection_materialize_with_missing_columns.sql) (in query: DROP DATABASE IF EXISTS test_x2uxhbo9 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:15:58.882288 [ 16690 ] {e209389a-258e-4a75-901b-5cbcb9d2c0ab} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:59.106328 [ 3739 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_34_40_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.39 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB.: (while reading column trace): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_34_34_0/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 2114): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:59.108252 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_34_40_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.71 GiB (attempt to allocate chunk of 1.39 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB.: (while reading column trace): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_34_34_0/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 2114): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:15:59.144937 [ 16054 ] {test_5_test_02585_query_to_kill_id_1} executeQuery: Code: 210. DB::Exception: Connection reset by peer, while writing to socket (127.0.0.1:42206 -> 127.0.0.2:9000): While executing ExternalTableSink: While executing Remote. (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47542) (comment: 02585_query_status_deadlock.sh) (query 2, line 3) (in query: select * from remote('127.0.0.2', 'system.numbers_mt') where number in (select * from tmp);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Client/Connection.cpp:986: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9d30e 7. ./build_docker/./src/Client/Connection.cpp:1117: DB::(anonymous namespace)::ExternalTableDataSink::consume(DB::Chunk) @ 0x000000003aab35d3 8. ./build_docker/./src/Processors/ISink.cpp:47: DB::ISink::work() @ 0x000000003b19046b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Client/Connection.cpp:1163: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003aaa43f6 14. ./build_docker/./src/Client/HedgedConnections.cpp:131: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x000000003ab2efff 15. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:928: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002f27ba1e 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:441: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278249 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 18. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 19. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 20. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:15:59.156038 [ 16390 ] {cf255de1-9f94-4cfb-bce0-36f6e4cb781f} executeQuery: Code: 60. DB::Exception: Table test_11.orc does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53188) (comment: 01308_orc_output_format_arrays.sh) (query 1, line 1) (in query: INSERT INTO orc VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:15:59.182610 [ 16390 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.orc does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:15:59.188820 [ 16054 ] {} TCPHandler: Code: 210. DB::Exception: Connection reset by peer, while writing to socket (127.0.0.1:42206 -> 127.0.0.2:9000): While executing ExternalTableSink: While executing Remote. (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Client/Connection.cpp:986: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9d30e 7. ./build_docker/./src/Client/Connection.cpp:1117: DB::(anonymous namespace)::ExternalTableDataSink::consume(DB::Chunk) @ 0x000000003aab35d3 8. ./build_docker/./src/Processors/ISink.cpp:47: DB::ISink::work() @ 0x000000003b19046b 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Client/Connection.cpp:1163: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003aaa43f6 14. ./build_docker/./src/Client/HedgedConnections.cpp:131: DB::HedgedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x000000003ab2efff 15. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:928: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002f27ba1e 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:441: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278249 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 18. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 19. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 20. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:15:59.447294 [ 16189 ] {665bd0f4-a756-49c8-b25b-7f17744a4db5} executeQuery: Code: 46. DB::Exception: Unknown table function test_02428_pv12. (UNKNOWN_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53206) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: SELECT * FROM test_02428_pv12(price=11)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:59.462298 [ 16047 ] {1a190756-0d09-44ff-858b-e85f8f9157ba} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 4. Bytes expected: 6271.: In scope SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 7, line 18) (in query: -- groupArray should check for errors in its input SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:425: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000020c4f774 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:687: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000020cf35cb 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:15:59.464412 [ 16189 ] {} TCPHandler: Code: 46. DB::Exception: Unknown table function test_02428_pv12. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:15:59.470103 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 4. Bytes expected: 6271.: In scope SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:425: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000020c4f774 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:687: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000020cf35cb 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:01.301957 [ 16047 ] {872c180c-4c00-4462-a19a-cd52f2083ddf} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 23. Bytes expected: 1016.: In scope SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 8, line 20) (in query: SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:337: DB::(anonymous namespace)::GroupArrayNumericImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000020c8d17a 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:01.307138 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 23. Bytes expected: 1016.: In scope SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:337: DB::(anonymous namespace)::GroupArrayNumericImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000020c8d17a 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:01.898149 [ 16390 ] {ae25771c-b1c7-42f3-8310-85b0e85f015a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'orc' in scope SELECT * FROM orc. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53218) (comment: 01308_orc_output_format_arrays.sh) (query 1, line 1) (in query: SELECT * FROM orc FORMAT ORC SETTINGS output_format_orc_compression_method='none'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:16:01.913769 [ 16390 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'orc' in scope SELECT * FROM orc. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:16:03.158296 [ 16047 ] {c6740b8a-b6c5-40cb-808e-561beed442dc} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 9, line 22) (in query: -- Same for groupArrayMovingXXXX SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingSumData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025aa4e27 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:03.170213 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingSumData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025aa4e27 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:03.978048 [ 17268 ] {ff36a511-56b3-49fe-85f6-4d6befa904d7} executeQuery: Code: 60. DB::Exception: Table test_11.orc does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53630) (comment: 01308_orc_output_format_arrays.sh) (query 1, line 1) (in query: DROP TABLE orc), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:04.098633 [ 17268 ] {} TCPHandler: Code: 60. DB::Exception: Table test_11.orc does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:06.110375 [ 16047 ] {e67f83e3-337a-4f81-bce5-46351f07dd46} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 10, line 24) (in query: SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingAvgData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025c4b979 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:06.134370 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArrayMoving.cpp:157: DB::MovingImpl, DB::MovingAvgData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025c4b979 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:07.904629 [ 16047 ] {5e437ef8-231e-4602-8d74-aa24b8b265d0} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 46. Bytes expected: 80.: In scope SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 11, line 26) (in query: -- Histogram SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:304: DB::(anonymous namespace)::AggregateFunctionHistogramData::read(DB::ReadBuffer&, unsigned int) @ 0x00000000259191a6 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:364: DB::(anonymous namespace)::AggregateFunctionHistogram::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025952029 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:07.916763 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 46. Bytes expected: 80.: In scope SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:304: DB::(anonymous namespace)::AggregateFunctionHistogramData::read(DB::ReadBuffer&, unsigned int) @ 0x00000000259191a6 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:364: DB::(anonymous namespace)::AggregateFunctionHistogram::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025952029 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:09.501659 [ 16691 ] {c7b40dc8-7722-4e0f-a962-246264c904df} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54374) (comment: 02731_parallel_replicas_join_subquery.sql) (query 2, line 5) (in query: CREATE TABLE join_inner_table (`id` UUID, `key` String, `number` Int64, `value1` String, `value2` String, `time` Int64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/join_inner_table', 'r1') ORDER BY (id, number, key) SETTINGS index_granularity = 39922, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 121455978, compact_parts_max_granules_to_buffer = 113, compact_parts_merge_max_bytes_to_prefetch_part = 21642007, merge_max_block_size = 7899, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 229751, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10105362565, index_granularity_bytes = 181164, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 74430, primary_key_compress_block_size = 44130, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:16:09.518005 [ 16691 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:16:10.328168 [ 16047 ] {42cc7b43-b909-4853-b060-ea6e20ef0b42} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 56. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 12, line 30) (in query: -- StatisticalSample SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./src/AggregateFunctions/StatCommon.h:116: DB::StatisticalSample::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000025db398e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:228: DB::(anonymous namespace)::AggregateFunctionMannWhitney::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025dbfbd2 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:10.342595 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 56. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./src/AggregateFunctions/StatCommon.h:116: DB::StatisticalSample::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000025db398e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:228: DB::(anonymous namespace)::AggregateFunctionMannWhitney::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025dbfbd2 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:11.381759 [ 19621 ] {5e43d675-0bcb-448d-b9e7-32b158444375} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45306) (comment: 01950_aliases_bad_cast.sql) (query 1, line 1) (in query: SELECT 1, * FROM (SELECT NULL AS `1`);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002eaf5e62 4. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002eaf7dbc 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:906: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f9c64 6. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 7. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 9. ./build_docker/./src/Planner/Planner.cpp:1828: DB::Planner::buildPlanForQueryNode() @ 0x0000000032c026ab 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:16:11.386801 [ 19621 ] {} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002eaf5e62 4. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002eaf7dbc 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:906: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f9c64 6. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 7. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 9. ./build_docker/./src/Planner/Planner.cpp:1828: DB::Planner::buildPlanForQueryNode() @ 0x0000000032c026ab 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:16:11.483052 [ 19621 ] {0289b3a1-9b26-496a-9edb-e11bccda56ed} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 'xyz' String Const(size = 0, String(size = 1)) 'xyz' Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45306) (comment: 01950_aliases_bad_cast.sql) (query 2, line 2) (in query: SELECT '7', 'xyz', * FROM (SELECT NULL AS `'xyz'`);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002eaf5e62 4. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002eaf7dbc 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:906: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f9c64 6. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 7. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 9. ./build_docker/./src/Planner/Planner.cpp:1828: DB::Planner::buildPlanForQueryNode() @ 0x0000000032c026ab 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:16:11.520492 [ 19621 ] {} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 'xyz' String Const(size = 0, String(size = 1)) 'xyz' Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x000000002eaf5e62 4. ./build_docker/./src/Core/Block.cpp:211: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x000000002eaf7dbc 5. ./build_docker/./src/Interpreters/ActionsDAG.cpp:906: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f9c64 6. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 7. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 9. ./build_docker/./src/Planner/Planner.cpp:1828: DB::Planner::buildPlanForQueryNode() @ 0x0000000032c026ab 10. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:16:12.490525 [ 16047 ] {71c3845d-97c8-4c4b-bfa1-c6dacf9fd734} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 64. Bytes expected: 240.: In scope SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 13, line 34) (in query: -- maxIntersections SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:153: DB::(anonymous namespace)::AggregateFunctionIntersectionsMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000258619ad 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:12.496012 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 64. Bytes expected: 240.: In scope SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:153: DB::(anonymous namespace)::AggregateFunctionIntersectionsMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000258619ad 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:14.610927 [ 16215 ] {1d4751f3-395b-4e8e-a523-6af147697403} executeQuery: Code: 46. DB::Exception: Unknown table function test_02428_mv1. (UNKNOWN_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45694) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: SELECT * FROM test_02428_mv1(test)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:16:14.617671 [ 16215 ] {} TCPHandler: Code: 46. DB::Exception: Unknown table function test_02428_mv1. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4747: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030426455 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:16:14.959396 [ 16047 ] {125b3646-ab4c-455b-85e8-ddc8247793a1} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 14, line 38) (in query: -- sequenceNextNode (This was fine because it would fail in the next readBinary call, but better to add a test) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(''forward'', ''head''), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000025de6729 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025df474b 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000266ac0aa 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 2025.11.13 09:16:14.979554 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000025de6729 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025df474b 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000266ac0aa 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 2025.11.13 09:16:15.743286 [ 16207 ] {b4fe709a-76c9-4be1-8995-d5a08d26da83} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37860) (comment: 03259_negate_key_overflow.sql) (in query: DROP DATABASE IF EXISTS test_rmsgtfaa SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:16:15.751189 [ 16207 ] {b4fe709a-76c9-4be1-8995-d5a08d26da83} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:16.620184 [ 16047 ] {9b77ed16-34e5-4583-969d-880781e60d5c} executeQuery: Code: 128. DB::Exception: Too large node state size: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (TOO_LARGE_ARRAY_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 15, line 43) (in query: -- Fuzzer (ALL) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:101: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000025de7370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025df474b 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000266ac0aa 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:16.630163 [ 16047 ] {} TCPHandler: Code: 128. DB::Exception: Too large node state size: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:101: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000025de7370 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025df474b 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000266ac0aa 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:16.768798 [ 16047 ] {c8ed0838-83d6-41c2-aa05-d4acbc25dce1} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 16, line 48) (in query: -- Fuzzer 2 (UBSAN) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000025de6729 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025df474b 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000266ac0aa 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 2025.11.13 09:16:16.774224 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:105: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x0000000025de6729 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:345: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000025df474b 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:191: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000266ac0aa 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 9. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 10. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 11. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 12. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 13. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 14. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 30. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 2025.11.13 09:16:16.817013 [ 16162 ] {1eaf7b34-1bfe-4b7b-a4b2-8ba87737c01d} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.27 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: In scope SELECT 1 AS a, a + a AS b, b + b AS c, c + c AS d, d + d AS e, e + e AS f, f + f AS g, g + g AS h, h + h AS i, i + i AS j, j + j AS k, k + k AS l, l + l AS m, m + m AS n, n + n AS o, o + o AS p, p + p AS q, q + q AS r, r + r AS s, s + s AS t, t + t AS u, u + u AS v, v + v AS w, w + w AS x, x + x AS y, y + y AS z. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38384) (comment: 00988_expansion_aliases_limit.sql) (query 1, line 1) (in query: SELECT 1 AS a, a + a AS b, b + b AS c, c + c AS d, d + d AS e, e + e AS f, f + f AS g, g + g AS h, h + h AS i, i + i AS j, j + j AS k, k + k AS l, l + l AS m, m + m AS n, n + n AS o, o + o AS p, p + p AS q, q + q AS r, r + r AS s, s + s AS t, t + t AS u, u + u AS v, v + v AS w, w + w AS x, x + x AS y, y + y AS z;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insert(DB::Field const&) @ 0x0000000037b2969b 13. ./build_docker/./src/DataTypes/IDataType.cpp:75: DB::IDataType::createColumnConst(unsigned long, DB::Field const&) const @ 0x000000002f4b3d79 14. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001889185b 15. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000018890670 16. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001888b046 17. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000188296fd 18. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001881feb2 19. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001881846b 20. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188146cd 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1243: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030447274 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1494: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449c4e 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 2025.11.13 09:16:16.841629 [ 16162 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.70 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.27 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: In scope SELECT 1 AS a, a + a AS b, b + b AS c, c + c AS d, d + d AS e, e + e AS f, f + f AS g, g + g AS h, h + h AS i, i + i AS j, j + j AS k, k + k AS l, l + l AS m, m + m AS n, n + n AS o, o + o AS p, p + p AS q, q + q AS r, r + r AS s, s + s AS t, t + t AS u, u + u AS v, v + v AS w, w + w AS x, x + x AS y, y + y AS z. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insert(DB::Field const&) @ 0x0000000037b2969b 13. ./build_docker/./src/DataTypes/IDataType.cpp:75: DB::IDataType::createColumnConst(unsigned long, DB::Field const&) const @ 0x000000002f4b3d79 14. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001889185b 15. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000018890670 16. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001888b046 17. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000188296fd 18. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001881feb2 19. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001881846b 20. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188146cd 21. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 22. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1243: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030447274 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1494: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449c4e 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 2025.11.13 09:16:16.949305 [ 3260 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1403: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000031b06d66 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1425: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000031b07f49 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:219: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031b2b7df 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:19.212302 [ 16231 ] {05e1a757-bb29-48b8-b41b-a46f7e6c9c75} executeQuery: Code: 81. DB::Exception: Database _table_function does not exist. (UNKNOWN_DATABASE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45326) (comment: 00459_group_array_insert_at.sql) (query 5, line 5) (in query: SELECT k, ignore(groupArrayInsertAt(x, x)) FROM (SELECT dummy AS k, (randConstant() * 10) % 10 AS x FROM remote('127.0.0.{1,1}', system.one)) GROUP BY k ORDER BY k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:721: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031aed626 5. ./build_docker/./src/Interpreters/Context.cpp:5666: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x0000000031846925 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:162: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111a3a4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5354: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7c72 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:213: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x00000000305722d8 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:198: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030571dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc3db 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./build_docker/./src/Processors/QueryPlan/ParallelReplicasLocalPlan.cpp:57: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x000000003c1ee9af 20. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:626: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000037038617 21. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:508: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000032c33d63 22. ./build_docker/./src/Planner/Planner.cpp:1548: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf5e23 23. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 24. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000032be23f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd625b 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:16:19.245823 [ 16231 ] {} TCPHandler: Code: 81. DB::Exception: Database _table_function does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:721: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x0000000031aed626 5. ./build_docker/./src/Interpreters/Context.cpp:5666: DB::Context::resolveStorageID(DB::StorageID, DB::Context::StorageNamespace) const @ 0x0000000031846925 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:162: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111a3a4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5354: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7c72 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:213: DB::QueryTreePassManager::run(std::shared_ptr, unsigned long) @ 0x00000000305722d8 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:198: DB::QueryTreePassManager::runOnlyResolve(std::shared_ptr) @ 0x0000000030571dce 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:149: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc3db 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./build_docker/./src/Processors/QueryPlan/ParallelReplicasLocalPlan.cpp:57: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x000000003c1ee9af 20. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:626: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x0000000037038617 21. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:508: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000032c33d63 22. ./build_docker/./src/Planner/Planner.cpp:1548: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf5e23 23. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 24. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000032be23f6 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd625b 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:16:19.510040 [ 16047 ] {4622357f-7056-4fe6-8eb9-8590409b823f} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 17, line 53) (in query: -- uniqUpTo SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:124: DB::(anonymous namespace)::AggregateFunctionUniqUpTo::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000253412a7 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:19.515175 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:124: DB::(anonymous namespace)::AggregateFunctionUniqUpTo::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000253412a7 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 8. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 9. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 11. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:20.816285 [ 17268 ] {05150a62-ead9-479d-9799-77e7ca013e9e} executeQuery: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46170) (comment: 02111_global_context_temporary_tables.sql) (query 1, line 1) (in query: -- { echo } SELECT * FROM remote('127.1', system.one, 1 IN id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x00000000338a2174 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x000000003389ed45 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000031c816aa 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c64d44 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c62015 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031c40935 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031bbaca6 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031bf3072 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031bf43af 16. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000384581b2 17. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038452433 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000266fbb40 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ed4f4 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 21. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:16:20.833624 [ 17268 ] {} TCPHandler: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x00000000338a2174 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x000000003389ed45 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000031c816aa 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c64d44 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c62015 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031c40935 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031bbaca6 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031bf3072 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031bf43af 16. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000384581b2 17. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038452433 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000266fbb40 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ed4f4 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 21. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:16:21.044549 [ 10170 ] {33b344ed-b509-4c30-94d1-3dd5bafe7f70} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 15 digits were read: '123456789123451'e-1. Expected to read decimal with scale 5 and precision 18: In scope SELECT CAST('12345678912345.1', 'Decimal(10, 5)'). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45936) (comment: 01327_decimal_cut_extra_digits_after_point.sql) (query 11, line 13) (in query: -- But it's just Decimal64, so there is the limit. SELECT CAST('12345678912345.1' AS Decimal(10, 5));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f46a3df 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e445e 6. COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002c6eeef8 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator()>>>(T const&) const @ 0x000000002c6be952 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6afe55 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6af404 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:16:21.058697 [ 17268 ] {4b3cf21a-a555-4cb4-a971-4eb7071fe451} executeQuery: Code: 60. DB::Exception: Table default.dummy does not exist: While processing 1 IN (dummy). (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46170) (comment: 02111_global_context_temporary_tables.sql) (query 2, line 3) (in query: SELECT * FROM remote('127.1', system.one, 1 IN dummy);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x00000000338a2174 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x000000003389ed45 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000031c816aa 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c64d44 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c62015 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031c40935 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031bbaca6 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031bf3072 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031bf43af 16. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000384581b2 17. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038452433 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000266fbb40 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ed4f4 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 21. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:16:21.059072 [ 10170 ] {} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 15 digits were read: '123456789123451'e-1. Expected to read decimal with scale 5 and precision 18: In scope SELECT CAST('12345678912345.1', 'Decimal(10, 5)'). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, String&&, int&, unsigned int&, unsigned int&) @ 0x000000002f46ea47 4. ./src/IO/readDecimalText.h:163: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x000000002f46a3df 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:46: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x000000002f5e445e 6. COW::immutable_ptr DB::detail::ConvertThroughParsing>, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002c6eeef8 7. bool std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const::'lambda'(T const&)::operator()>>>(T const&) const @ 0x000000002c6be952 8. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c6afe55 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c6af404 10. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:16:21.073411 [ 17268 ] {} TCPHandler: Code: 60. DB::Exception: Table default.dummy does not exist: While processing 1 IN (dummy). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x00000000338a2174 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x000000003389ed45 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000031c816aa 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c64d44 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c62015 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031c40935 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031bbaca6 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031bf3072 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031bf43af 16. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000384581b2 17. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038452433 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000266fbb40 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ed4f4 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 21. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:16:21.271124 [ 17268 ] {7416b2e4-216a-478c-90f4-87a015f19e2a} executeQuery: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46170) (comment: 02111_global_context_temporary_tables.sql) (query 3, line 4) (in query: SELECT * FROM remote('127.1', view(SELECT * FROM system.one), 1 IN id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x00000000338a2174 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x000000003389ed45 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000031c816aa 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c64d44 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c62015 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031c40935 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031bbaca6 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031bf3072 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031bf43af 16. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000384581b2 17. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038452433 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000266fbb40 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ed4f4 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 21. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:16:21.294675 [ 17268 ] {} TCPHandler: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x00000000338a2174 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x000000003389ed45 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000031c816aa 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c64d44 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c62015 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031c40935 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031bbaca6 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031bf3072 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031bf43af 16. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000384581b2 17. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038452433 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000266fbb40 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ed4f4 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 21. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:16:21.637995 [ 17268 ] {4ce87105-4142-4ba0-b1f0-a36685af7b3f} executeQuery: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46170) (comment: 02111_global_context_temporary_tables.sql) (query 4, line 5) (in query: SELECT * FROM remote('127.1', view(SELECT number AS id FROM numbers(2)), 1 IN id);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x00000000338a2174 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x000000003389ed45 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000031c816aa 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c64d44 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c62015 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031c40935 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031bbaca6 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031bf3072 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031bf43af 16. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000384581b2 17. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038452433 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000266fbb40 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ed4f4 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 21. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:16:21.643491 [ 17268 ] {} TCPHandler: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x00000000338a2174 8. ./build_docker/./src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x000000003389ed45 9. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x0000000031c816aa 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c64d44 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c62015 12. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031c40935 13. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031bbaca6 14. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031bf3072 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031bf43af 16. ./build_docker/./src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x00000000384581b2 17. ./build_docker/./src/Storages/StorageDistributed.cpp:408: DB::StorageDistributed::StorageDistributed(DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, String const&, String const&, std::shared_ptr, std::shared_ptr const&, String const&, String const&, DB::DistributedSettings const&, DB::LoadingStrictnessLevel, std::shared_ptr, std::shared_ptr, bool) @ 0x0000000038452433 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, String const&, String const&, String, std::shared_ptr&, std::shared_ptr const&, String, String, DB::DistributedSettings, DB::LoadingStrictnessLevel, std::shared_ptr const&, std::shared_ptr const&, bool, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, String const&, String const&, String&&, std::shared_ptr&, std::shared_ptr const&, String&&, String&&, DB::DistributedSettings&&, DB::LoadingStrictnessLevel&&, std::shared_ptr const&, std::shared_ptr const&, bool&&) @ 0x00000000266fbb40 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ed4f4 20. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 21. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:16:21.953591 [ 16047 ] {ad70ec0c-5371-4227-9505-ddca8b24f1e1} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 18, line 57) (in query: -- quantiles SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./src/AggregateFunctions/QuantileExact.h:64: DB::QuantileExactBase>::deserialize(DB::ReadBuffer&) @ 0x0000000021708c98 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:247: DB::AggregateFunctionQuantile, DB::NameQuantileExact, false, void, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002170306f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:22.030505 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./src/AggregateFunctions/QuantileExact.h:64: DB::QuantileExactBase>::deserialize(DB::ReadBuffer&) @ 0x0000000021708c98 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:247: DB::AggregateFunctionQuantile, DB::NameQuantileExact, false, void, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002170306f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:22.316222 [ 16605 ] {fd4a7daa-aaec-48da-8a06-b8dd5ea6895d} executeQuery: Code: 60. DB::Exception: Table test_omnb98dj.test_02428_pv5 does not exist. Maybe you meant test_omnb98dj.test_02428_pv4?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41728) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: DROP VIEW test_02428_pv5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:22.375494 [ 16605 ] {} TCPHandler: Code: 60. DB::Exception: Table test_omnb98dj.test_02428_pv5 does not exist. Maybe you meant test_omnb98dj.test_02428_pv4?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:23.357615 [ 19619 ] {4dc3a752-6c8d-4cc0-83e4-dce4be211262} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=875). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46546) (comment: 02458_datediff_date32.sql) (query 18, line 26) (in query: SELECT dateDiff('minute', toDateTime64('1927-01-01 00:00:00', 3, 'UTC'), toDate32('1927-01-02', 'UTC'), 'UTC');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:16:23.371540 [ 19619 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=875). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:16:24.658526 [ 16047 ] {ab8befc5-15e9-42f8-b4c8-0d450aa30879} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)')). (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48196) (comment: 02477_invalid_reads.sql) (query 19, line 60) (in query: SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./src/AggregateFunctions/QuantileTDigest.h:319: DB::QuantileTDigest::deserialize(DB::ReadBuffer&) @ 0x00000000224cf062 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:247: DB::AggregateFunctionQuantile, DB::NameQuantileTDigest, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000224c1a6f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:24.672146 [ 16047 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)')). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./src/AggregateFunctions/QuantileTDigest.h:319: DB::QuantileTDigest::deserialize(DB::ReadBuffer&) @ 0x00000000224cf062 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:247: DB::AggregateFunctionQuantile, DB::NameQuantileTDigest, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000224c1a6f 7. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000002f5a2331 8. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5a2adc 9. DB::detail::ConvertImplGenericFromString::executeImpl(DB::IColumn const&, DB::IColumn&, DB::ISerialization const&, unsigned long, DB::PODArray, 63ul, 64ul> const*, DB::IDataType const*, std::shared_ptr const&) @ 0x000000002c3520cb 10. DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x000000002c34f3b9 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c9296bc 12. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:16:27.101697 [ 18771 ] {12eba464-5cc1-4aba-8aac-852f176904f6} executeQuery: Code: 60. DB::Exception: Table test_omnb98dj.test_02428_pv8 does not exist. Maybe you meant test_omnb98dj.test_02428_pv4?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42358) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: DROP VIEW test_02428_pv8), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:27.118940 [ 18771 ] {} TCPHandler: Code: 60. DB::Exception: Table test_omnb98dj.test_02428_pv8 does not exist. Maybe you meant test_omnb98dj.test_02428_pv4?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:27.567455 [ 6070 ] {45cff4d0-0c39-4659-9eaf-76ade703b680} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(1., 1.). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42066) (comment: 02715_bit_operations_float.sql) (query 3, line 4) (in query: SELECT bitAnd(1.0, 1.0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b49c8b6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b26d5b9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:16:27.576452 [ 6070 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function bitAnd: In scope SELECT bitAnd(1., 1.). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b49c8b6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b26d5b9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:16:29.940685 [ 6070 ] {f721ffe6-b44a-41a8-a24c-b4042a58ed24} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function bitOr: In scope SELECT bitOr(1., 1.). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42066) (comment: 02715_bit_operations_float.sql) (query 4, line 5) (in query: SELECT bitOr(1.0, 1.0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c0c69b6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000be7fa19 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:16:29.945301 [ 6070 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function bitOr: In scope SELECT bitOr(1., 1.). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c0c69b6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000be7fa19 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:16:30.253010 [ 16446 ] {904af80e-b2d0-4c93-a363-141262a91e54} executeQuery: Code: 60. DB::Exception: Table test_omnb98dj.test_02428_pv10 does not exist. Maybe you meant test_omnb98dj.test_02428_mv1?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42828) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: DROP VIEW test_02428_pv10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:30.275641 [ 16446 ] {} TCPHandler: Code: 60. DB::Exception: Table test_omnb98dj.test_02428_pv10 does not exist. Maybe you meant test_omnb98dj.test_02428_mv1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:30.790871 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 945.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:30.791499 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 945.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:30.821965 [ 17268 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 941.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:30.822605 [ 17268 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 941.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:31.478551 [ 6070 ] {e63a16fd-c394-46b9-87b9-1183c4c33086} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42066) (comment: 02715_bit_operations_float.sql) (query 5, line 6) (in query: SELECT bitRotateLeft(1.0, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c305c96 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c0f8319 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:16:31.483353 [ 6070 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c305c96 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c0f8319 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:16:31.680742 [ 16199 ] {41f425e3-7e19-4c09-9f02-8f7cfd66d403} executeQuery: Code: 60. DB::Exception: Table test_omnb98dj.test_02428_pv11 does not exist. Maybe you meant test_omnb98dj.test_02428_mv1?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33528) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: DROP VIEW test_02428_pv11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:31.762371 [ 16199 ] {} TCPHandler: Code: 60. DB::Exception: Table test_omnb98dj.test_02428_pv11 does not exist. Maybe you meant test_omnb98dj.test_02428_mv1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:32.049314 [ 18376 ] {60393340-8700-429e-a558-d71ba2e90ff5} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic and cannot be applied on fly. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42046) (comment: 03047_on_fly_mutations_non_deterministic_replace.sql) (query 18, line 37) (in query: SELECT id, length(v) FROM t_lightweight_mut_5 ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/AlterConversions.cpp:95: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x0000000039afa2de 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8688: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039a3e103 6. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:158: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x000000003c340b24 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:53: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c33f0fd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:26: DB::MergeTreeReadPoolInOrder::MergeTreeReadPoolInOrder(bool, DB::MergeTreeReadType, DB::RangesInDataParts, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c3f8609 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolInOrder* std::construct_at[abi:ne190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolInOrder*>(DB::MergeTreeReadPoolInOrder*, bool&, DB::MergeTreeReadType&, DB::RangesInDataParts&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x000000003c3008c8 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readInOrder(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings, DB::MergeTreeReadType, unsigned long) @ 0x000000003c271c85 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:763: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003c2781bc 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:965: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003c27aace 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2128: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003c2c322f 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2226: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c9ebb 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:16:32.057195 [ 18376 ] {} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic and cannot be applied on fly. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/AlterConversions.cpp:95: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x0000000039afa2de 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8688: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039a3e103 6. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:158: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x000000003c340b24 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:53: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c33f0fd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:26: DB::MergeTreeReadPoolInOrder::MergeTreeReadPoolInOrder(bool, DB::MergeTreeReadType, DB::RangesInDataParts, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c3f8609 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolInOrder* std::construct_at[abi:ne190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolInOrder*>(DB::MergeTreeReadPoolInOrder*, bool&, DB::MergeTreeReadType&, DB::RangesInDataParts&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x000000003c3008c8 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readInOrder(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings, DB::MergeTreeReadType, unsigned long) @ 0x000000003c271c85 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:763: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003c2781bc 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:965: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003c27aace 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2128: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003c2c322f 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2226: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c9ebb 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:16:32.506879 [ 18728 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 936.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:32.507481 [ 18728 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 936.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:32.994245 [ 17268 ] {b3b58e2b-ecf9-4a16-b505-77bb5c7ba867} executeQuery: Code: 60. DB::Exception: Table test_omnb98dj.test_02428_pv12 does not exist. Maybe you meant test_omnb98dj.test_02428_mv1?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33774) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: DROP VIEW test_02428_pv12), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:33.033430 [ 17268 ] {} TCPHandler: Code: 60. DB::Exception: Table test_omnb98dj.test_02428_pv12 does not exist. Maybe you meant test_omnb98dj.test_02428_mv1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:16:33.380527 [ 6070 ] {fea6bd97-0628-43fe-b47c-e6c5d3e3223b} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42066) (comment: 02715_bit_operations_float.sql) (query 6, line 7) (in query: SELECT bitShiftLeft(1.0, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c81e7b6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c575759 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:16:33.386570 [ 6070 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c81e7b6 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000c575759 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:16:34.758376 [ 10170 ] {d6eafedc-b97c-4196-9b89-ce7541448897} executeQuery: Code: 43. DB::Exception: Point's component must not be NaN: In scope SELECT arrayMap(a -> arrayMap(b -> arrayMap(c -> (round(c.1, 6), round(c.2, 6)), b), a), polygonsUnionCartesian([[[(2., 100.0000991821289), (0., 3.), (1., 2.9), (2., 2.6), (2.6, 2.), (2.9, 1), (3., 0.), (100.0000991821289, 2.)]]], [[[(1., 1.), (1000.0001220703125, nan), (4., 4.), (4., 1.), (1., 1.)]]])). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33508) (comment: 01305_polygons_union.sql) (query 2, line 3) (in query: SELECT arrayMap(a -> arrayMap(b -> arrayMap(c -> (round(c.1, 6), round(c.2, 6)), b), a), polygonsUnionCartesian([[[(2., 100.0000991821289), (0., 3.), (1., 2.9), (2., 2.6), (2.6, 2.), (2.9, 1), (3., 0.), (100.0000991821289, 2.)]]], [[[(1., 1.), (1000.0001220703125, nan), (4., 4.), (4., 1.), (1., 1.)]]]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::ColumnToPointsConverter>::convert(COW::immutable_ptr) @ 0x0000000018e1b99a 5. DB::ColumnToRingsConverter>::convert(COW::immutable_ptr) @ 0x0000000018e1f502 6. DB::ColumnToPolygonsConverter>::convert(COW::immutable_ptr) @ 0x0000000018e21a56 7. DB::ColumnToMultiPolygonsConverter>::convert(COW::immutable_ptr) @ 0x0000000018e24b69 8. void DB::callOnGeometryDataType, auto void DB::callOnTwoGeometryDataTypes, DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, auto const&)>(std::shared_ptr, std::shared_ptr, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(std::shared_ptr, auto&&) @ 0x0000000019d3aa3b 9. void DB::callOnGeometryDataType, void DB::callOnTwoGeometryDataTypes, DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, auto const&)>(std::shared_ptr, std::shared_ptr, auto&&)::'lambda'(auto const&)>(std::shared_ptr, auto&&) @ 0x0000000019d13662 10. DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019d10b37 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:34.764121 [ 10170 ] {} TCPHandler: Code: 43. DB::Exception: Point's component must not be NaN: In scope SELECT arrayMap(a -> arrayMap(b -> arrayMap(c -> (round(c.1, 6), round(c.2, 6)), b), a), polygonsUnionCartesian([[[(2., 100.0000991821289), (0., 3.), (1., 2.9), (2., 2.6), (2.6, 2.), (2.9, 1), (3., 0.), (100.0000991821289, 2.)]]], [[[(1., 1.), (1000.0001220703125, nan), (4., 4.), (4., 1.), (1., 1.)]]])). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::ColumnToPointsConverter>::convert(COW::immutable_ptr) @ 0x0000000018e1b99a 5. DB::ColumnToRingsConverter>::convert(COW::immutable_ptr) @ 0x0000000018e1f502 6. DB::ColumnToPolygonsConverter>::convert(COW::immutable_ptr) @ 0x0000000018e21a56 7. DB::ColumnToMultiPolygonsConverter>::convert(COW::immutable_ptr) @ 0x0000000018e24b69 8. void DB::callOnGeometryDataType, auto void DB::callOnTwoGeometryDataTypes, DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, auto const&)>(std::shared_ptr, std::shared_ptr, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)>(std::shared_ptr, auto&&) @ 0x0000000019d3aa3b 9. void DB::callOnGeometryDataType, void DB::callOnTwoGeometryDataTypes, DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, auto const&)>(std::shared_ptr, std::shared_ptr, auto&&)::'lambda'(auto const&)>(std::shared_ptr, auto&&) @ 0x0000000019d13662 10. DB::(anonymous namespace)::FunctionPolygonsUnion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000019d10b37 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 2025.11.13 09:16:34.947014 [ 6070 ] {1f9d1051-e882-4607-8c5a-87ffbcc098f4} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42066) (comment: 02715_bit_operations_float.sql) (query 7, line 8) (in query: SELECT bitTest(1.0, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000cd1c956 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cb42499 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:16:34.951978 [ 6070 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and UInt8 of arguments of function bitTest: In scope SELECT bitTest(1., 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000cd1c956 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cb42499 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:16:36.197085 [ 4028 ] {1c068cc4-e980-4cbe-902e-3064e7e75a1a} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33978) (comment: 02428_parameterized_view.sh) (query 1, line 1) (in query: DROP TABLE 02428_parameterized_view_test_omnb98dj.pv1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:16:36.428662 [ 4028 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:16:36.771153 [ 18376 ] {298651d5-7d29-4ff7-99ce-48c629894b34} executeQuery: Code: 57. DB::Exception: Table test_nqwgs97i.t_lightweight_mut_5 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42046) (comment: 03047_on_fly_mutations_non_deterministic_replace.sql) (query 24, line 52) (in query: CREATE TABLE t_lightweight_mut_5 (`id` UInt64, `v` AggregateFunction(uniqExact, UInt64)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 55493, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 367210746, compact_parts_max_bytes_to_buffer = 338820368, compact_parts_max_granules_to_buffer = 158, compact_parts_merge_max_bytes_to_prefetch_part = 23244504, merge_max_block_size = 9413, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 4873990985, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 6718904773, index_granularity_bytes = 26661294, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 28039, primary_key_compress_block_size = 23636, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:16:36.792754 [ 18376 ] {} TCPHandler: Code: 57. DB::Exception: Table test_nqwgs97i.t_lightweight_mut_5 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:16:37.305197 [ 18728 ] {0605efc2-34db-4d57-9e1e-e64cc8f85c50} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33996) (comment: 03247_create-same-table-concurrently-with-atomic-engine.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_5_db SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:16:37.324583 [ 18728 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:16:37.541211 [ 2998 ] {25035192-51bd-4573-94e1-8c72dc1ae0b9} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45754) (comment: 02014_storage_merge_order_by.sql) (query 16, line 22) (in query: DROP TABLE IF EXISTS merged;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:16:37.548928 [ 2998 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:16:39.168104 [ 16397 ] {76cf514c-0f52-46d8-82fa-051ca8823302} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45506) (comment: 03093_analyzer_miel_test.sql) (in query: DROP DATABASE IF EXISTS test_xnad8blw SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:16:39.173001 [ 16397 ] {76cf514c-0f52-46d8-82fa-051ca8823302} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:39.236889 [ 6078 ] {8289a09e-3d03-49f4-9e3b-1d401b9ab82e} executeQuery: Code: 731. DB::Exception: use_query_cache and overflow_mode != 'throw' cannot be used together. (QUERY_CACHE_USED_WITH_NON_THROW_OVERFLOW_MODE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34054) (comment: 00266_read_overflow_mode.sql) (query 1, line 1) (in query: SELECT number AS k FROM (SELECT number FROM system.numbers LIMIT 110000 SETTINGS max_result_rows = 0) GROUP BY k ORDER BY k LIMIT 10 SETTINGS max_result_rows = 100000, result_overflow_mode = 'break';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033836774 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:16:39.258660 [ 6078 ] {} TCPHandler: Code: 731. DB::Exception: use_query_cache and overflow_mode != 'throw' cannot be used together. (QUERY_CACHE_USED_WITH_NON_THROW_OVERFLOW_MODE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033836774 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:16:41.520196 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 905.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.520883 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 905.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.538376 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 904.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.544397 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 904.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.568906 [ 3735 ] {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_74_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 902.84 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.570111 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_74_15}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 902.84 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.654000 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.654614 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.668321 [ 16691 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.668959 [ 16691 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.670681 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.676536 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.713490 [ 16691 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.713549 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.714181 [ 16691 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.720442 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.731107 [ 16691 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.731763 [ 16691 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.741444 [ 16230 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.742041 [ 16230 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.742541 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.743064 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 903.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.757825 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 2304 entries up to offset 291486: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.95 MiB (attempt to allocate chunk of 4.11 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.772693 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 900.24 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.780390 [ 16691 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 892.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.782952 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 900.24 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.783953 [ 16691 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 892.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.797463 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 880.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.798128 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 880.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.810681 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 880.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:41.811308 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 880.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.233885 [ 16198 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 879.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.234495 [ 16198 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 879.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.326226 [ 18700 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 881.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.326957 [ 18700 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 881.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.336598 [ 3728 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_89_18} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 880.97 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.337915 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_89_18}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 880.97 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.396482 [ 18728 ] {d793c12c-096f-4be4-a7d6-7a3439be00c9} executeQuery: Code: 57. DB::Exception: Table test_9.test_null_as_default already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34092) (comment: 01846_null_as_default_for_insert_select.sql) (query 15, line 20) (in query: CREATE TABLE test_null_as_default (a Int8, b Int64 DEFAULT a + 1000) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:16:42.420290 [ 18728 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.test_null_as_default already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:16:42.776732 [ 16352 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 894.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.777367 [ 16352 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 894.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.779913 [ 3726 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_1_67_10} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 905.84 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (avg_value_size_hint = 45.0245361328125, avg_chars_size = 44.429443359375, limit = 8192): (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_1_47_9/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.781322 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_1_67_10}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 905.84 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (avg_value_size_hint = 45.0245361328125, avg_chars_size = 44.429443359375, limit = 8192): (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_1_47_9/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.796332 [ 16352 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 884.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.796948 [ 16352 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 884.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.863160 [ 16691 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 882.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.863898 [ 16691 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 882.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:42.894034 [ 16189 ] {ab356b9e-9f44-4340-92ef-6a5e55c3093e} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 902.84 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33402) (comment: 03300_merge_parts_metric.sh) (query 22, line 22) (in query: INSERT INTO test SELECT sum(length(source_part_names)) = (SELECT value FROM system.metrics WHERE name = 'MergeParts') FROM system.merges;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:16:43.005303 [ 18096 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.005971 [ 18096 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.040571 [ 18096 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 845.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.041149 [ 18096 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 845.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.042916 [ 16233 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 845.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.043444 [ 16233 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 845.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.046368 [ 18096 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 845.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.046905 [ 18096 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 845.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.052295 [ 18096 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 845.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.071430 [ 16189 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 902.84 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:16:43.075470 [ 3725 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_89_18} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 847.40 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.076691 [ 18096 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 845.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.079012 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_89_18}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 847.40 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.117303 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 847.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.118686 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 847.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.148718 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 844.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:43.167306 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 844.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.107999 [ 3731 ] {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_74_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 894.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.122347 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_74_15}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 894.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.215969 [ 16703 ] {5eb54c35-c304-4262-9cf0-4535e1a1592b} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 881.69 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48742) (comment: 02122_parallel_formatting_RowBinary.sh) (query 1, line 1) (in query: select number, number + 1, concat('string: ', toString(number)) from numbers(200000) group by number with totals order by number limit 190000 format RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000031f717cd 12. ./src/Common/HashTable/HashTable.h:1039: TwoLevelHashTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>, 8ul>::TwoLevelHashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>>(HashMapTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator> const&) @ 0x00000000327c4491 13. ./src/Common/HashTable/TwoLevelHashMap.h:23: DB::AggregatedDataVariants::convertToTwoLevel() @ 0x00000000327a42dd 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1603: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb4560 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 16. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:16:44.240591 [ 3732 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_55_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 847.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b29a0d 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.245649 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_55_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 847.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b29a0d 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.267912 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_75_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 882.01 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: While executing MergingSortedTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000a39c0f4 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037af730b 13. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:0: DB::ColumnLowCardinality::Index::insertPositionsRange(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003752f6ae 14. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:220: DB::ColumnLowCardinality::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003752d1a3 15. ./src/Columns/IColumn.h:210: DB::ColumnTuple::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037779980 16. ./src/Columns/IColumn.h:210: DB::ColumnArray::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x000000003709f2e8 17. ./src/Columns/IColumn.h:198: DB::ColumnMap::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x00000000375e5cff 18. ./src/Columns/IColumn.h:198: DB::MergedData::insertRow(std::vector> const&, unsigned long, unsigned long) @ 0x000000003beb032f 19. ./build_docker/./src/Processors/Merges/Algorithms/MergingSortedAlgorithm.cpp:205: DB::IMergingAlgorithm::Status DB::MergingSortedAlgorithm::mergeImpl>(DB::SortingQueueImpl&) @ 0x000000003bf79d39 20. ./build_docker/./src/Processors/Merges/Algorithms/MergingSortedAlgorithm.cpp:123: _ZNSt3__116__variant_detail12__visitation6__base12__dispatcherIJLm26EEE10__dispatchB8ne190107IONS1_9__variant15__value_visitorIRZN2DB22MergingSortedAlgorithm5mergeEvE3$_0EEJRNS0_6__baseILNS0_6_TraitE1EJNS8_16SortingQueueImplINS8_33SpecializedSingleColumnSortCursorINS8_12ColumnVectorIDuEEEELNS8_20SortingQueueStrategyE0EEENSG_INSH_INSI_ItEEEELSL_0EEENSG_INSH_INSI_IjEEEELSL_0EEENSG_INSH_INSI_ImEEEELSL_0EEENSG_INSH_INSI_IN4wide7integerILm128EjEEEEEELSL_0EEENSG_INSH_INSI_INSX_ILm256EjEEEEEELSL_0EEENSG_INSH_INSI_IDB8_EEEELSL_0EEENSG_INSH_INSI_IsEEEELSL_0EEENSG_INSH_INSI_IiEEEELSL_0EEENSG_INSH_INSI_IlEEEELSL_0EEENSG_INSH_INSI_INSX_ILm128EiEEEEEELSL_0EEENSG_INSH_INSI_INSX_ILm256EiEEEEEELSL_0EEENSG_INSH_INSI_I8BFloat16EEEELSL_0EEENSG_INSH_INSI_IfEEEELSL_0EEENSG_INSH_INSI_IdEEEELSL_0EEENSG_INSH_INS8_13ColumnDecimalINS8_7DecimalIiEEEEEELSL_0EEENSG_INSH_INS21_INS22_IlEEEEEELSL_0EEENSG_INSH_INS21_INS22_IS1J_EEEEEELSL_0EEENSG_INSH_INS21_INS22_IS1N_EEEEEELSL_0EEENSG_INSH_INS21_INS8_10DateTime64EEEEELSL_0EEENSG_INSH_INSI_I13StrongTypedefISY_NS8_7UUIDTagEEEEEELSL_0EEENSG_INSH_INSI_INS8_4IPv4EEEEELSL_0EEENSG_INSH_INSI_INS8_4IPv6EEEEELSL_0EEENSG_INSH_INS8_12ColumnStringEEELSL_0EEENSG_INSH_INS8_17ColumnFixedStringEEELSL_0EEENSG_INS8_16SimpleSortCursorELSL_0EEENSG_INS8_10SortCursorELSL_0EEENSG_INS8_23SortCursorWithCollationELSL_0EEEEEEEEEDcT_DpT0_ @ 0x000000003bec4d73 21. ./contrib/llvm-project/libcxx/include/variant:508: DB::MergingSortedAlgorithm::merge() @ 0x000000003beb66eb 22. ./src/Processors/Merges/IMergingTransform.h:137: DB::IMergingTransform::work() @ 0x00000000330e2299 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.269694 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_75_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 882.01 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: While executing MergingSortedTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000a39c0f4 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037af730b 13. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:0: DB::ColumnLowCardinality::Index::insertPositionsRange(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003752f6ae 14. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:220: DB::ColumnLowCardinality::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003752d1a3 15. ./src/Columns/IColumn.h:210: DB::ColumnTuple::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037779980 16. ./src/Columns/IColumn.h:210: DB::ColumnArray::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x000000003709f2e8 17. ./src/Columns/IColumn.h:198: DB::ColumnMap::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x00000000375e5cff 18. ./src/Columns/IColumn.h:198: DB::MergedData::insertRow(std::vector> const&, unsigned long, unsigned long) @ 0x000000003beb032f 19. ./build_docker/./src/Processors/Merges/Algorithms/MergingSortedAlgorithm.cpp:205: DB::IMergingAlgorithm::Status DB::MergingSortedAlgorithm::mergeImpl>(DB::SortingQueueImpl&) @ 0x000000003bf79d39 20. ./build_docker/./src/Processors/Merges/Algorithms/MergingSortedAlgorithm.cpp:123: _ZNSt3__116__variant_detail12__visitation6__base12__dispatcherIJLm26EEE10__dispatchB8ne190107IONS1_9__variant15__value_visitorIRZN2DB22MergingSortedAlgorithm5mergeEvE3$_0EEJRNS0_6__baseILNS0_6_TraitE1EJNS8_16SortingQueueImplINS8_33SpecializedSingleColumnSortCursorINS8_12ColumnVectorIDuEEEELNS8_20SortingQueueStrategyE0EEENSG_INSH_INSI_ItEEEELSL_0EEENSG_INSH_INSI_IjEEEELSL_0EEENSG_INSH_INSI_ImEEEELSL_0EEENSG_INSH_INSI_IN4wide7integerILm128EjEEEEEELSL_0EEENSG_INSH_INSI_INSX_ILm256EjEEEEEELSL_0EEENSG_INSH_INSI_IDB8_EEEELSL_0EEENSG_INSH_INSI_IsEEEELSL_0EEENSG_INSH_INSI_IiEEEELSL_0EEENSG_INSH_INSI_IlEEEELSL_0EEENSG_INSH_INSI_INSX_ILm128EiEEEEEELSL_0EEENSG_INSH_INSI_INSX_ILm256EiEEEEEELSL_0EEENSG_INSH_INSI_I8BFloat16EEEELSL_0EEENSG_INSH_INSI_IfEEEELSL_0EEENSG_INSH_INSI_IdEEEELSL_0EEENSG_INSH_INS8_13ColumnDecimalINS8_7DecimalIiEEEEEELSL_0EEENSG_INSH_INS21_INS22_IlEEEEEELSL_0EEENSG_INSH_INS21_INS22_IS1J_EEEEEELSL_0EEENSG_INSH_INS21_INS22_IS1N_EEEEEELSL_0EEENSG_INSH_INS21_INS8_10DateTime64EEEEELSL_0EEENSG_INSH_INSI_I13StrongTypedefISY_NS8_7UUIDTagEEEEEELSL_0EEENSG_INSH_INSI_INS8_4IPv4EEEEELSL_0EEENSG_INSH_INSI_INS8_4IPv6EEEEELSL_0EEENSG_INSH_INS8_12ColumnStringEEELSL_0EEENSG_INSH_INS8_17ColumnFixedStringEEELSL_0EEENSG_INS8_16SimpleSortCursorELSL_0EEENSG_INS8_10SortCursorELSL_0EEENSG_INS8_23SortCursorWithCollationELSL_0EEEEEEEEEDcT_DpT0_ @ 0x000000003bec4d73 21. ./contrib/llvm-project/libcxx/include/variant:508: DB::MergingSortedAlgorithm::merge() @ 0x000000003beb66eb 22. ./src/Processors/Merges/IMergingTransform.h:137: DB::IMergingTransform::work() @ 0x00000000330e2299 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.335406 [ 16703 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 881.69 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000031f717cd 12. ./src/Common/HashTable/HashTable.h:1039: TwoLevelHashTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable, HashTableNoState, PairNoInit>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>, 8ul>::TwoLevelHashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>>(HashMapTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator> const&) @ 0x00000000327c4491 13. ./src/Common/HashTable/TwoLevelHashMap.h:23: DB::AggregatedDataVariants::convertToTwoLevel() @ 0x00000000327a42dd 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1603: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb4560 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 16. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 21. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:16:44.642593 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 830.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.643256 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 830.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.676117 [ 19243 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 826.71 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.676818 [ 19243 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 826.71 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.699050 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 823.71 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.699678 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 823.71 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.745843 [ 18771 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 823.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.746490 [ 18771 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 823.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.934810 [ 2996 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 810.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:44.935430 [ 2996 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 810.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:46.143958 [ 3729 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_89_18} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 830.96 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:46.245117 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_89_18}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 830.96 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:46.560671 [ 16693 ] {375dcdda-82a3-4a5c-bf80-d84da7501595} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 900.33 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform: while pushing to view test_dy39gv30.test_race_condition_mv1_4 (49b67a4a-0f87-4470-8799-235c94cb98aa). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33536) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (query 1, line 1) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 412, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003bd8f50b 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0eb49 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0dabf 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:16:46.717040 [ 16693 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 900.33 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform: while pushing to view test_dy39gv30.test_race_condition_mv1_4 (49b67a4a-0f87-4470-8799-235c94cb98aa). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003bd8f50b 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0eb49 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0dabf 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 25. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:16:54.762470 [ 3124 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1403: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000031b06d66 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1425: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000031b07f49 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:219: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031b2b7df 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:54.964451 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 554.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:54.965469 [ 6078 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 554.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:54.965778 [ 18700 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 554.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:54.966732 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 554.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:54.967435 [ 6078 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 554.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:54.967985 [ 18700 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 554.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:54.970267 [ 18728 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 551.50 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:54.970861 [ 18728 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 551.50 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:56.884209 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_78_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 553.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:56.885772 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_78_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 553.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:16:56.898337 [ 17390 ] {c75b930e-f84c-4132-a783-dd205426c327} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 555.06 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing JoiningTransform: while pushing to view test_dy39gv30.test_race_condition_mv1_3 (1bed4c8f-9abb-4552-b94f-ce8fb40e301f). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42850) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (query 1, line 1) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 0, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::PODArray, 63ul, 64ul>::resize_fill(unsigned long, long const&) @ 0x000000001f87d6fd 12. ./src/Columns/ColumnVector.h:81: DB::ColumnVector::doInsertManyFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037ba7850 13. ./src/Columns/IColumn.h:225: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const::$_0::operator()(DB::Block const&) const @ 0x0000000033be6091 14. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:912: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x0000000033be1b2a 15. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1050: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9a8b 16. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x000000003bb312b0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x000000003bb30551 18. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x000000003bb2ca24 19. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x000000003bb2b629 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 24. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003bd8f50b 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0eb49 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0dabf 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 2025.11.13 09:16:57.055461 [ 17390 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 555.06 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing JoiningTransform: while pushing to view test_dy39gv30.test_race_condition_mv1_3 (1bed4c8f-9abb-4552-b94f-ce8fb40e301f). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::PODArray, 63ul, 64ul>::resize_fill(unsigned long, long const&) @ 0x000000001f87d6fd 12. ./src/Columns/ColumnVector.h:81: DB::ColumnVector::doInsertManyFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037ba7850 13. ./src/Columns/IColumn.h:225: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const::$_0::operator()(DB::Block const&) const @ 0x0000000033be6091 14. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:912: DB::HashJoin::joinBlockImplCross(DB::Block&, std::shared_ptr&) const @ 0x0000000033be1b2a 15. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1050: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033be9a8b 16. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x000000003bb312b0 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x000000003bb30551 18. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x000000003bb2ca24 19. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x000000003bb2b629 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 24. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003bd8f50b 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0eb49 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0dabf 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:17:00.069083 [ 17376 ] {2efd15a6-0ffe-407f-95a4-24bccf09212d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40216) (comment: 00808_not_optimize_predicate.sql) (query 11, line 15) (in query: SELECT * FROM (SELECT * FROM test_00808 ORDER BY id LIMIT 1) WHERE id = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eeed2a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ee4a84 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039ee43c9 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039ba06ba 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b8f2f5 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:277: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b5e2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:76: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3f962b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c3564d3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 2025.11.13 09:17:00.098795 [ 17376 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eeed2a 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ee4a84 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:59: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039ee43c9 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039ba06ba 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:52: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b8f2f5 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:277: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b5e2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:76: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3f962b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c3564d3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:00.185053 [ 2998 ] {a5b6d61d-4dbb-4155-a706-1e80078e5002} executeQuery: Code: 57. DB::Exception: Table test_3.dt already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40702) (comment: 00745_compile_scalar_subquery.sql) (query 12, line 16) (in query: CREATE TABLE dt (`tkey` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 22084, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 73693153, compact_parts_max_granules_to_buffer = 174, compact_parts_merge_max_bytes_to_prefetch_part = 32459538, merge_max_block_size = 19292, old_parts_lifetime = 32., prefer_fetch_merged_part_size_threshold = 9560827466, vertical_merge_algorithm_min_rows_to_activate = 261424, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 25774672, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 46282, primary_key_compress_block_size = 96730, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:00.205335 [ 2998 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.dt already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:00.639683 [ 18771 ] {5a82b3c2-8cdd-4063-8d10-8fc75b95184b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49412) (comment: 02014_storage_merge_order_by.sql) (query 13, line 18) (in query: select sum(e) from (select * from merged order by t limit 10) SETTINGS max_threads = 50;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:828: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039c3bc0b 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1866: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c2aea5b 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1572: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c2aa6a2 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1567: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c2a9e37 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2055: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c2c0e58 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2163: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c795c 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 14. ./build_docker/./src/Storages/StorageMerge.cpp:1146: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000387b1d68 15. ./build_docker/./src/Storages/StorageMerge.cpp:532: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000387ae810 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:17:00.661247 [ 18771 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:828: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039c3bc0b 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1866: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c2aea5b 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1572: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c2aa6a2 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1567: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c2a9e37 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2055: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c2c0e58 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2163: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c795c 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 14. ./build_docker/./src/Storages/StorageMerge.cpp:1146: DB::ReadFromMerge::buildPipeline(DB::ReadFromMerge::ChildPlan&, DB::QueryProcessingStage::Enum) const @ 0x00000000387b1d68 15. ./build_docker/./src/Storages/StorageMerge.cpp:532: DB::ReadFromMerge::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000387ae810 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:17:01.012952 [ 16703 ] {b0813dfa-5a1d-44ee-a2a1-ebc4840f12fc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36822) (comment: 00808_not_optimize_predicate.sql) (in query: DROP DATABASE IF EXISTS test_z4l7gg87 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:17:01.026401 [ 16703 ] {b0813dfa-5a1d-44ee-a2a1-ebc4840f12fc} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:01.127511 [ 17653 ] {1d079bb1-4f41-48a2-8ade-00ec88dc6798} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58892) (comment: 02014_storage_merge_order_by.sql) (in query: DROP DATABASE IF EXISTS test_n9p706fz SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:17:01.136947 [ 17653 ] {1d079bb1-4f41-48a2-8ade-00ec88dc6798} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:01.830238 [ 16230 ] {4be8ec1c-e106-409b-bb85-78085f472044} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36000) (comment: 02125_constant_if_condition_and_not_existing_column.sql) (query 2, line 2) (in query: -- this queries does not have to pass, but they works historically -- let's support this while can, see #31687 create table test (x String) Engine=StripeLog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:01.886643 [ 16230 ] {} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:02.585052 [ 2997 ] {3f8914bc-b9af-47be-9485-5c5067c2a34a} executeQuery: Code: 497. DB::Exception: user_03273_dictionary_rbac_test_15: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_15.dict_03273_dictionary_rbac_test_15: In scope SELECT dictGet(dict_03273_dictionary_rbac_test_15, 'value', 1). (ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41018) (comment: 03273_dictionary_rbac.sh) (query 1, line 2) (in query: SELECT dictGet(dict_03273_dictionary_rbac_test_15, 'value', 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e3a78db 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e3a3d96 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e3a2306 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e31aa78 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003186786f 8. ./build_docker/./src/Interpreters/Context.cpp:1751: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000317cbe0f 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000910ac3e 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000910026f 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:17:02.603226 [ 2997 ] {} TCPHandler: Code: 497. DB::Exception: user_03273_dictionary_rbac_test_15: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_15.dict_03273_dictionary_rbac_test_15: In scope SELECT dictGet(dict_03273_dictionary_rbac_test_15, 'value', 1). (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e3a78db 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e3a3d96 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e3a2306 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e31aa78 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003186786f 8. ./build_docker/./src/Interpreters/Context.cpp:1751: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000317cbe0f 9. DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000910ac3e 10. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000910026f 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 12. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:17:04.088318 [ 19621 ] {22be20cb-15f7-42be-94f2-a73274e57071} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35868) (comment: 01752_distributed_query_sigsegv.sql) (query 1, line 3) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:04.103248 [ 19621 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:04.119035 [ 16231 ] {97d38a6e-37dc-4993-9c39-9fe79c932d49} executeQuery: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36072) (comment: 01752_distributed_query_sigsegv.sql) (query 1, line 3) (in query: -- this is enough to trigger the regression SELECT throwIf(dummy = 0) FROM remote('127.1', system.one);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:17:04.141191 [ 16231 ] {} TCPHandler: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:05.607754 [ 17385 ] {33cd5565-8ccb-4b43-917d-50d2635be3cd} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56892) (comment: 01752_distributed_query_sigsegv.sql) (query 2, line 6) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:05.650352 [ 17385 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:05.851158 [ 16398 ] {e8a79ab4-b6a8-41f3-a5db-28a5ecade7b5} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35872) (comment: 01752_distributed_query_sigsegv.sql) (query 2, line 6) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:05.859314 [ 16398 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:05.865258 [ 16231 ] {39514c43-86cc-408b-8099-7461f1434933} executeQuery: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36072) (comment: 01752_distributed_query_sigsegv.sql) (query 2, line 6) (in query: -- these are just in case SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:17:05.874414 [ 16398 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:35872, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:05.888443 [ 16398 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:35872, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:05.916834 [ 16231 ] {} TCPHandler: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:06.000297 [ 16446 ] {62b3bcde-2fef-4eca-913f-03c81d86998d} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3EdgeAngle is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3EdgeAngle(100). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36182) (comment: 01273_h3EdgeAngle_range_check.sql) (query 1, line 3) (in query: SELECT h3EdgeAngle(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000f13f7d7 4. DB::(anonymous namespace)::FunctionH3EdgeAngle::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000115eb574 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:17:06.010511 [ 16446 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (100) of function h3EdgeAngle is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3EdgeAngle(100). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000f13f7d7 4. DB::(anonymous namespace)::FunctionH3EdgeAngle::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000115eb574 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:17:06.721849 [ 18700 ] {59794b6a-cb21-4ae7-8fb0-052babbc3531} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56896) (comment: 01752_distributed_query_sigsegv.sql) (query 3, line 8) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:06.751780 [ 18700 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:07.093348 [ 16231 ] {82553752-f7c4-470b-8f08-3f3c0c97b0bd} executeQuery: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36072) (comment: 01752_distributed_query_sigsegv.sql) (query 3, line 8) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:17:07.157290 [ 16231 ] {} TCPHandler: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:07.352109 [ 16200 ] {0e581a47-4ef1-4bab-b2aa-2244d02eedea} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35882) (comment: 01752_distributed_query_sigsegv.sql) (query 3, line 8) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:07.365326 [ 16200 ] {0e581a47-4ef1-4bab-b2aa-2244d02eedea} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:35882). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003aecc107 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000003aea56e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:07.407553 [ 16200 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:08.207207 [ 16889 ] {421dce88-0743-4802-a884-b2415e30fc7f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35898) (comment: 01752_distributed_query_sigsegv.sql) (query 4, line 9) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:08.220099 [ 16889 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:08.368539 [ 17228 ] {d953e87d-b945-4927-88b5-e3f6c8e78166} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56902) (comment: 01752_distributed_query_sigsegv.sql) (query 4, line 9) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:08.440381 [ 17228 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:08.492054 [ 16231 ] {3d48a2b0-09dd-494d-bb9b-e915fd472429} executeQuery: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36072) (comment: 01752_distributed_query_sigsegv.sql) (query 4, line 9) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0, distributed_group_by_no_merge=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:17:08.525829 [ 16231 ] {} TCPHandler: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:09.661307 [ 16323 ] {f5e2f8a8-3376-4ff3-bd33-2d0f481f4f0d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35904) (comment: 01752_distributed_query_sigsegv.sql) (query 5, line 10) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:09.693266 [ 16323 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:10.241154 [ 16162 ] {6ef5dd6f-2e91-4110-a51c-cdb6caf8096c} executeQuery: Code: 59. DB::Exception: Illegal type Int128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36714) (comment: 02473_prewhere_with_bigint.sql) (query 7, line 8) (in query: SELECT a FROM prewhere_int128 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:71: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003c48fa64 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:275: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039f3f01f 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:350: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c2681f1 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:10.358862 [ 16162 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Int128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:71: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003c48fa64 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:275: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039f3f01f 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:350: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c2681f1 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:10.361965 [ 16231 ] {d22d8c7d-5134-4733-9635-74af7c8fc510} executeQuery: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36072) (comment: 01752_distributed_query_sigsegv.sql) (query 5, line 10) (in query: SELECT throwIf(dummy = 0) FROM remote('127.{1,2}', system.one) SETTINGS prefer_localhost_replica=0, distributed_group_by_no_merge=2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:17:10.394490 [ 16231 ] {} TCPHandler: Code: 395. DB::Exception: Received from 127.1:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:10.600027 [ 16703 ] {bcd729e2-578d-45c1-8a6e-040621279089} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56928) (comment: 01752_distributed_query_sigsegv.sql) (query 5, line 10) (in query: SELECT throwIf(`__table1`.`dummy` = 0) AS `throwIf(equals(dummy, 0))` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:10.617239 [ 16703 ] {bcd729e2-578d-45c1-8a6e-040621279089} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:56928). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003aecc107 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000003aea56e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:10.627817 [ 16703 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.dummy, 0_UInt8) :: 0) -> throwIf(equals(__table1.dummy, 0_UInt8)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:11.446492 [ 3138 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1403: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000031b06d66 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1425: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000031b07f49 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:219: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031b2b7df 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:11.462525 [ 16162 ] {1bf9fcfd-fa4e-48a5-b97c-e77f1d88f47a} executeQuery: Code: 59. DB::Exception: Illegal type Int256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36714) (comment: 02473_prewhere_with_bigint.sql) (query 11, line 13) (in query: SELECT a FROM prewhere_int256 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:71: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003c48fa64 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:275: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039f3f01f 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:350: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c2681f1 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:11.468730 [ 16162 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type Int256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:71: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003c48fa64 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:275: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039f3f01f 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:350: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c2681f1 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:13.003069 [ 16162 ] {c1ba7a73-a508-4725-aa7b-22b78ed81e52} executeQuery: Code: 59. DB::Exception: Illegal type UInt128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36714) (comment: 02473_prewhere_with_bigint.sql) (query 15, line 18) (in query: SELECT a FROM prewhere_uint128 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:71: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003c48fa64 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:275: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039f3f01f 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:350: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c2681f1 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:13.011548 [ 16162 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:71: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003c48fa64 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:275: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039f3f01f 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:350: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c2681f1 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:13.416329 [ 18722 ] {e7690212-de25-4dcd-ac83-d31097026fa5} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table = 'test_local_1'. (ILLEGAL_PREWHERE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36702) (comment: 00717_merge_and_distributed.sql) (query 19, line 24) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table = 'test_local_1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:13.429155 [ 18722 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table = 'test_local_1'. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:13.914724 [ 16162 ] {e597f0cc-9254-492f-afa7-e9180415edfb} executeQuery: Code: 59. DB::Exception: Illegal type UInt256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36714) (comment: 02473_prewhere_with_bigint.sql) (query 19, line 23) (in query: SELECT a FROM prewhere_uint256 PREWHERE a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:71: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003c48fa64 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:275: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039f3f01f 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:350: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c2681f1 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:13.922446 [ 16162 ] {} TCPHandler: Code: 59. DB::Exception: Illegal type UInt256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/QueryPlan/SourceStepWithFilter.cpp:71: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003c48fa64 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:275: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039f3f01f 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:350: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c2681f1 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:13.984003 [ 18722 ] {569253ed-a770-47b3-afef-bda76adc6bb6} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table IN ('test_local_1', 'test_local_2'). (ILLEGAL_PREWHERE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36702) (comment: 00717_merge_and_distributed.sql) (query 21, line 26) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table in ('test_local_1', 'test_local_2');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:13.990680 [ 18722 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1') PREWHERE _table IN ('test_local_1', 'test_local_2'). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:14.132635 [ 16889 ] {7c967bd1-814c-4d1e-96f7-ea46642093b1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45938) (comment: 03247_create-same-table-concurrently-with-atomic-engine.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_5_db SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:17:14.145506 [ 16889 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:17:15.180164 [ 16198 ] {7be63d02-267f-4636-a067-7ddf0daf4d10} executeQuery: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36816) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 17, line 39) (in query: ALTER TABLE table_with_version MODIFY COLUMN version String;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3479: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039926a31 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:15.185280 [ 16198 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version to type String because version column must be of an integer type or of type Date or DateTime. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3479: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039926a31 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:15.319678 [ 19194 ] {7ab0fb0b-39e5-4598-ae63-8b5fdb940b03} executeQuery: Code: 691. DB::Exception: Unknown element 'c' for enum, maybe you meant: ['a']: while converting 'c' to Enum8('a' = 1, 'b' = 2). (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45858) (comment: 03278_enum_in_unknown_value.sql) (query 18, line 29) (in query: SELECT * FROM t_enum_in_unknown_value WHERE e IN ('a', 'b', 'c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002f4845ac 5. ./build_docker/./src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6401dd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003377fa14 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000337834d0 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000031158ac0 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000031152544 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000003117cdf0 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba11 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003117b8ab 14. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bef988 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:15.326167 [ 19194 ] {} TCPHandler: Code: 691. DB::Exception: Unknown element 'c' for enum, maybe you meant: ['a']: while converting 'c' to Enum8('a' = 1, 'b' = 2). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002f4845ac 5. ./build_docker/./src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6401dd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003377fa14 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000337834d0 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000031158ac0 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000031152544 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000003117cdf0 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba11 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003117b8ab 14. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bef988 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:15.363077 [ 19194 ] {5c6e184a-90b2-4795-9ebc-4986b0f78970} executeQuery: Code: 691. DB::Exception: Unknown element 'c' for enum, maybe you meant: ['a']: while converting 'c' to Enum8('a' = 1, 'b' = 2). (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45858) (comment: 03278_enum_in_unknown_value.sql) (query 19, line 30) (in query: SELECT * FROM t_enum_in_unknown_value WHERE e NOT IN ('a', 'b', 'c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002f4845ac 5. ./build_docker/./src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6401dd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003377fa14 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000337834d0 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000031158ac0 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000031152544 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000003117cdf0 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba11 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003117b8ab 14. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bef988 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:15.368252 [ 19194 ] {} TCPHandler: Code: 691. DB::Exception: Unknown element 'c' for enum, maybe you meant: ['a']: while converting 'c' to Enum8('a' = 1, 'b' = 2). (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/DataTypes/EnumValues.cpp:72: DB::EnumValues<_BitInt(8)>::getValue(StringRef) const @ 0x000000002f4845ac 5. ./build_docker/./src/DataTypes/Serializations/SerializationEnum.cpp:99: DB::SerializationEnum<_BitInt(8)>::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6401dd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003377fa14 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000337834d0 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000031158ac0 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000031152544 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000003117cdf0 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba11 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003117b8ab 14. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bef988 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:16.030211 [ 16198 ] {eb2a9e0a-93c6-4128-8524-eb921e28dfde} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36816) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 18, line 40) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Int64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3495: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039927135 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:16.037782 [ 16198 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Int64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3495: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039927135 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:16.445123 [ 19194 ] {d761ce4a-8cd6-4f83-be0d-c4a05275c712} executeQuery: Code: 691. DB::Exception: Unexpected value 3 in enum. (UNKNOWN_ELEMENT_OF_ENUM) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45858) (comment: 03278_enum_in_unknown_value.sql) (query 20, line 31) (in query: SELECT * FROM t_enum_in_unknown_value WHERE e IN ('a', 'b', 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d18b934 5. ./src/DataTypes/EnumValues.h:54: DB::DataTypeEnum<_BitInt(8)>::castToValue(DB::Field const&) const @ 0x000000002f32e3bd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:264: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003377d5f6 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000337834d0 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000031158ac0 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000031152544 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000003117cdf0 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba11 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003117b8ab 14. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bef988 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:16.450924 [ 19194 ] {} TCPHandler: Code: 691. DB::Exception: Unexpected value 3 in enum. (UNKNOWN_ELEMENT_OF_ENUM), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::EnumValues<_BitInt(8)>::findByValue(DB::EnumValues<_BitInt(8)> const&) const @ 0x000000000d18b934 5. ./src/DataTypes/EnumValues.h:54: DB::DataTypeEnum<_BitInt(8)>::castToValue(DB::Field const&) const @ 0x000000002f32e3bd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:264: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003377d5f6 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x00000000337834d0 9. ./build_docker/./src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x0000000031158ac0 10. ./build_docker/./src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x0000000031152544 11. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000003117cdf0 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba11 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003117b8ab 14. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bef988 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:16.731234 [ 16198 ] {1e2db9ca-0307-4143-9a9a-2a9c26c83894} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36816) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 19, line 41) (in query: ALTER TABLE table_with_version MODIFY COLUMN version UInt16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3504: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039926db5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:16.735914 [ 16198 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type UInt16 because new type is smaller than current in the number of bytes. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3504: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039926db5 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:16.904225 [ 16198 ] {50b50674-55a0-46e5-a567-dac31764048d} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36816) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 20, line 42) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Float64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3495: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039927135 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:16.909547 [ 16198 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Float64 because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3495: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039927135 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:16.990229 [ 16198 ] {69a4bdcc-9fd3-454c-a8a0-a6fcef61b69a} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36816) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 21, line 43) (in query: ALTER TABLE table_with_version MODIFY COLUMN version Date;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3495: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039927135 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:16.998667 [ 16198 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type Date because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3495: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039927135 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:17.105445 [ 18728 ] {0e8f9abc-997f-4bce-946d-2736ade650c8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36754) (comment: 03300_merge_parts_metric.sh) (query 24, line 24) (in query: INSERT INTO test SELECT sum(length(source_part_names)) = (SELECT value FROM system.metrics WHERE name = 'MergeParts') FROM system.merges;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:17:17.124137 [ 16198 ] {57a9888f-c396-435a-9d88-597560736ba7} executeQuery: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36816) (comment: 01511_alter_version_versioned_collapsing_merge_tree.sql) (query 22, line 44) (in query: ALTER TABLE table_with_version MODIFY COLUMN version DateTime;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3495: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039927135 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:17.130070 [ 18728 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:17:17.142506 [ 16198 ] {} TCPHandler: Code: 524. DB::Exception: Cannot alter version column version from type UInt32 to type DateTime because new type will change sort order of version column. The only possible conversion is expansion of the number of bytes of the current type. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3495: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039927135 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:17.240875 [ 18722 ] {8a172703-3886-44e0-865b-91afa21334bc} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_distributed_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_distributed_1') PREWHERE _table = 'test_distributed_1'. (ILLEGAL_PREWHERE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36702) (comment: 00717_merge_and_distributed.sql) (query 27, line 33) (in query: SELECT * FROM merge(currentDatabase(), 'test_distributed_1') PREWHERE _table = 'test_distributed_1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:17.247737 [ 18722 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_distributed_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_distributed_1') PREWHERE _table = 'test_distributed_1'. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:18.469158 [ 18376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 791.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.470026 [ 18376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 791.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.482824 [ 18376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 791.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.483688 [ 18376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 791.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.509656 [ 2997 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.510348 [ 2997 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.515094 [ 18376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.515723 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.515740 [ 16398 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.515731 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.515749 [ 18376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.521183 [ 18376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.521285 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.521974 [ 16398 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.522742 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.523327 [ 18376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.533160 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.533906 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.564524 [ 6072 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.04 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.616420 [ 6072 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 789.04 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:18.711232 [ 18722 ] {7ef83de7-679d-4b4d-8783-480d1c1c1a22} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_distributed_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_distributed_1') PREWHERE _table IN ('test_distributed_1', 'test_distributed_2'). (ILLEGAL_PREWHERE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36702) (comment: 00717_merge_and_distributed.sql) (query 29, line 35) (in query: SELECT * FROM merge(currentDatabase(), 'test_distributed_1') PREWHERE _table in ('test_distributed_1', 'test_distributed_2');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:18.721938 [ 18722 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_distributed_1') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_distributed_1') PREWHERE _table IN ('test_distributed_1', 'test_distributed_2'). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:19.976703 [ 3728 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_57_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 786.05 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:19.982682 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_57_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 786.05 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:20.871856 [ 18722 ] {1a875d5a-3dc7-45d8-b5d8-994192f84a81} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_local_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table = 'test_local_1'. (ILLEGAL_PREWHERE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36702) (comment: 00717_merge_and_distributed.sql) (query 35, line 42) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table = 'test_local_1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:20.916240 [ 18722 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_local_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table = 'test_local_1'. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:21.474242 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_78_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 788.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.10 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:21.475868 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_78_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 788.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.10 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:21.703089 [ 18722 ] {b18a2c42-accd-4a03-bea2-53cfc877c7d5} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_local_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table IN ('test_local_1', 'test_local_2') ORDER BY value ASC. (ILLEGAL_PREWHERE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36702) (comment: 00717_merge_and_distributed.sql) (query 37, line 44) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table in ('test_local_1', 'test_local_2') ORDER BY value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:21.719380 [ 18722 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_local_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_local_2') PREWHERE _table IN ('test_local_1', 'test_local_2') ORDER BY value ASC. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:22.176838 [ 18149 ] {598e10d2-c48d-4da9-a168-6d8ac5a1b12d} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `value` in scope SELECT * FROM merge(currentDatabase(), '') WHERE value = 1048575. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46010) (comment: 02522_different_types_in_storage_merge.sql) (query 6, line 8) (in query: SELECT * FROM merge(currentDatabase(), '') WHERE value = 1048575;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5659: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc365 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:22.240567 [ 18149 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `value` in scope SELECT * FROM merge(currentDatabase(), '') WHERE value = 1048575. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5659: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc365 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:23.640862 [ 3727 ] {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_79_16} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:23.672990 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_79_16}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:24.348563 [ 16200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:17:24.569524 [ 16200 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:17:32.584289 [ 18722 ] {6ba7dead-84d0-4c38-b6b2-a0be7871a792} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_distributed_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_distributed_2') PREWHERE _table = 'test_local_1'. (ILLEGAL_PREWHERE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36702) (comment: 00717_merge_and_distributed.sql) (query 43, line 51) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1|test_distributed_2') PREWHERE _table = 'test_local_1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:32.598529 [ 18722 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_distributed_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_distributed_2') PREWHERE _table = 'test_local_1'. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:33.851372 [ 19618 ] {7dffc2c9-81f8-47a5-85bc-dd2e4a701671} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33486) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (query 1, line 1) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 422, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003af1530b 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003aefe7bb 4. ./build_docker/./src/Server/TCPHandler.cpp:693: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003af12a8e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b1c1adc 6. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:17:34.058149 [ 19618 ] {7dffc2c9-81f8-47a5-85bc-dd2e4a701671} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33486). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003aecc107 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000003aea56e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:34.064600 [ 19618 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003af1530b 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003aefe7bb 4. ./build_docker/./src/Server/TCPHandler.cpp:693: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003af12a8e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b1c1adc 6. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:17:34.470443 [ 16605 ] {bd17a82a-0631-4e33-a2db-abf646e3a5ee} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 61504.060122 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33574) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (query 1, line 1) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 459, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c52d9 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 2025.11.13 09:17:34.499394 [ 16605 ] {bd17a82a-0631-4e33-a2db-abf646e3a5ee} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33574). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003aecc107 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000003aea56e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:34.511732 [ 16605 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 61504.060122 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c52d9 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:17:34.909735 [ 18824 ] {70a07be4-7379-477e-b506-6a93bf625bd7} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40818) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (query 1, line 1) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 462, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003af1530b 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003aefe7bb 4. ./build_docker/./src/Server/TCPHandler.cpp:693: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003af12a8e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b1c1adc 6. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:17:34.909559 [ 16344 ] {9f9f66bb-f6ff-4cbb-9fa5-fdaf5001e9f9} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49624) (comment: 02479_race_condition_between_insert_and_droppin_mv.sh) (query 1, line 1) (in query: INSERT INTO test_race_condition_landing SELECT number, toString(number), toString(number) from system.numbers limit 819, 500 settings ignore_materialized_views_with_dropped_target_table=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003af1530b 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003aefe7bb 4. ./build_docker/./src/Server/TCPHandler.cpp:693: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003af12a8e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b1c1adc 6. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:17:35.367271 [ 16344 ] {9f9f66bb-f6ff-4cbb-9fa5-fdaf5001e9f9} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:49624). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003aecc107 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000003aea56e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:35.372519 [ 16344 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003af1530b 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003aefe7bb 4. ./build_docker/./src/Server/TCPHandler.cpp:693: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003af12a8e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b1c1adc 6. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:17:35.373485 [ 18722 ] {84b8c057-60ad-40bb-8a97-82b53e75a61e} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_distributed_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_distributed_2') PREWHERE _table IN ('test_local_1', 'test_distributed_2') ORDER BY value ASC. (ILLEGAL_PREWHERE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36702) (comment: 00717_merge_and_distributed.sql) (query 45, line 53) (in query: SELECT * FROM merge(currentDatabase(), 'test_local_1|test_distributed_2') PREWHERE _table in ('test_local_1', 'test_distributed_2') ORDER BY value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:35.420605 [ 18722 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_local_1|test_distributed_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_local_1|test_distributed_2') PREWHERE _table IN ('test_local_1', 'test_distributed_2') ORDER BY value ASC. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:35.546842 [ 18824 ] {70a07be4-7379-477e-b506-6a93bf625bd7} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:40818). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003aecc107 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000003aea56e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:35.552237 [ 18824 ] {} TCPHandler: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x000000003af1530b 3. ./build_docker/./src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x000000003aefe7bb 4. ./build_docker/./src/Server/TCPHandler.cpp:693: bool std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003af12a8e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003b1c1adc 6. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:17:36.868177 [ 6078 ] {98812e0e-3859-40d5-bd48-0d086d370256} executeQuery: Code: 1. DB::Exception: Lambda as function argument resolved as list node with size 2. Expected 1. In scope x -> compound_value.*. (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56870) (comment: 02343_analyzer_lambdas.sql) (query 29, line 52) (in query: WITH cast(tuple(1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT arrayMap(x -> compound_value.*, [1,2,3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3443: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030479b8e 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:36.912092 [ 6078 ] {} TCPHandler: Code: 1. DB::Exception: Lambda as function argument resolved as list node with size 2. Expected 1. In scope x -> compound_value.*. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3443: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030479b8e 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:38.422272 [ 4451 ] {ce422e76-dce2-4a50-8f17-da99e1e94011} BackupsWorker: Failed to restore from backup Null: Code: 599. DB::Exception: Backup Null not found (cannot restore from Null). (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Backups/BackupIO_Null.cpp:97: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002e8c4687 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e8591a4 6. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002e826ca6 7. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002e828c44 8. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002e84f8ec 9. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002e83a9fe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d8c52e1 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::__packaged_task_func (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'(), std::allocator (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x000000002d8c512d 12. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002d8c59bd 13. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d8c582e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d8c3461 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d8c2e80 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e8174b6 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e815e18 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x00000000339e7f29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:38.516556 [ 19194 ] {ce422e76-dce2-4a50-8f17-da99e1e94011} executeQuery: Code: 599. DB::Exception: Backup Null not found (cannot restore from Null). (BACKUP_NOT_FOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46434) (comment: 03286_backup_to_null.sql) (query 6, line 10) (in query: RESTORE TABLE t1 FROM Null FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Backups/BackupIO_Null.cpp:97: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002e8c4687 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e8591a4 6. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002e826ca6 7. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002e828c44 8. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002e84f8ec 9. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002e83a9fe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d8c52e1 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::__packaged_task_func (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'(), std::allocator (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x000000002d8c512d 12. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002d8c59bd 13. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d8c582e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:17:38.535807 [ 19194 ] {} TCPHandler: Code: 599. DB::Exception: Backup Null not found (cannot restore from Null). (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Backups/BackupIO_Null.cpp:97: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl[abi:ne190107] (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000002e8c4687 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e8591a4 6. ./build_docker/./src/Backups/BackupsWorker.cpp:874: DB::BackupsWorker::openBackupForReading(DB::BackupInfo const&, DB::RestoreSettings const&, std::shared_ptr const&) const @ 0x000000002e826ca6 7. ./build_docker/./src/Backups/BackupsWorker.cpp:896: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&) @ 0x000000002e828c44 8. ./build_docker/./src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x000000002e84f8ec 9. ./build_docker/./src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002e83a9fe 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d8c52e1 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::__packaged_task_func (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'(), std::allocator (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x000000002d8c512d 12. ./contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000002d8c59bd 13. ./src/Common/threadPoolCallbackRunner.h:52: void std::__function::__policy_invoker::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority)::'lambda0'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d8c582e 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d8c3461 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d8c2e80 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002e8174b6 7. ./build_docker/./src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x000000002e815e18 8. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x00000000339e7f29 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:17:39.643734 [ 18722 ] {4e7548d8-38cf-47e8-a7dc-0c962ef33a3a} executeQuery: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_distributed_1|test_distributed_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_distributed_1|test_distributed_2') PREWHERE _table = 'test_distributed_1'. (ILLEGAL_PREWHERE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36702) (comment: 00717_merge_and_distributed.sql) (query 51, line 60) (in query: SELECT * FROM merge(currentDatabase(), 'test_distributed_1|test_distributed_2') PREWHERE _table = 'test_distributed_1';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:39.675504 [ 18722 ] {} TCPHandler: Code: 182. DB::Exception: Table expression merge(currentDatabase(), 'test_distributed_1|test_distributed_2') does not support column __table1._table in PREWHERE. In query SELECT * FROM merge(currentDatabase(), 'test_distributed_1|test_distributed_2') PREWHERE _table = 'test_distributed_1'. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000031172a92 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000311724db 7. ./build_docker/./src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x0000000031169d52 8. ./build_docker/./src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf129f 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:40.018949 [ 18722 ] {eda259dd-710d-4506-b026-4257f6ea4bf2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=878). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36702) (comment: 00717_merge_and_distributed.sql) (query 52, line 61) (in query: SELECT * FROM merge(currentDatabase(), 'test_distributed_1|test_distributed_2') WHERE _table in ('test_distributed_1', 'test_distributed_2') ORDER BY value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:40.058880 [ 18722 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=878). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:17:40.172615 [ 6078 ] {de3b6c34-4e8f-4867-ac8c-a579aa1ea2a3} executeQuery: Code: 1. DB::Exception: APPLY transformer APPLY x -> compound_value.* resolved as list node with size 2. Expected 1. In scope WITH CAST((1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table. (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56870) (comment: 02343_analyzer_lambdas.sql) (query 32, line 56) (in query: WITH cast(tuple(1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY x -> compound_value.* FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long&, String&&) @ 0x00000000304cb95f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2365: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030497df1 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3802: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030415bb9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:40.179113 [ 6078 ] {} TCPHandler: Code: 1. DB::Exception: APPLY transformer APPLY x -> compound_value.* resolved as list node with size 2. Expected 1. In scope WITH CAST((1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long&, String&&) @ 0x00000000304cb95f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2365: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030497df1 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3802: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030415bb9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:43.392550 [ 4028 ] {9cc65678-69b7-44f5-8903-3d5a4ee47ab3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57368) (comment: 02428_parameterized_view.sh) (in query: DROP DATABASE IF EXISTS test_omnb98dj SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:17:43.399113 [ 4028 ] {9cc65678-69b7-44f5-8903-3d5a4ee47ab3} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:43.409182 [ 3412 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1403: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000031b06d66 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1425: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000031b07f49 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:219: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031b2b7df 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:17:44.599583 [ 17268 ] {adf20b04-b527-49e9-9602-c210954f5daf} executeQuery: Code: 469. DB::Exception: Constraint `bogus` for table _temporary_and_external_tables.`_tmp_690e68ea-86ff-4bf2-abc6-f33e97be2ec0` (690e68ea-86ff-4bf2-abc6-f33e97be2ec0) is violated at row 1. Expression: (0). Column values: . (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47850) (comment: 01358_constexpr_constraint.sql) (query 5, line 12) (in query: INSERT INTO constrained VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:44.633516 [ 17268 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `bogus` for table _temporary_and_external_tables.`_tmp_690e68ea-86ff-4bf2-abc6-f33e97be2ec0` (690e68ea-86ff-4bf2-abc6-f33e97be2ec0) is violated at row 1. Expression: (0). Column values: . (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:17:45.860586 [ 18149 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:17:45.861315 [ 18149 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:17:46.168969 [ 6078 ] {c3299390-5876-4b3d-bc4c-60672abd64f8} executeQuery: Code: 36. DB::Exception: Lambda x -> (x + 1) is not allowed in expression context. In scope WITH (x, y) -> y AS lambda SELECT arrayMap(x -> (x + 1), [1, 2, 3]), (x -> (x + 1)), 1 AS x. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56870) (comment: 02343_analyzer_lambdas.sql) (query 46, line 86) (in query: -- lambda(tuple(x), x + 1) parsed as lambda definion but not as call of lambda defined in WITH WITH (x, y) -> y AS lambda SELECT arrayMap(lambda(tuple(x), x + 1), [1, 2, 3]), lambda(tuple(x), x + 1), 1 AS x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3849: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030419832 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:46.181252 [ 6078 ] {} TCPHandler: Code: 36. DB::Exception: Lambda x -> (x + 1) is not allowed in expression context. In scope WITH (x, y) -> y AS lambda SELECT arrayMap(x -> (x + 1), [1, 2, 3]), (x -> (x + 1)), 1 AS x. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3849: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030419832 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:46.738341 [ 5803 ] {ea5c8ed4-0321-4e0e-bf49-7b5315edd3f3} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48394) (comment: 02456_keeper_retries_during_insert.sql) (query 3, line 6) (in query: CREATE TABLE keeper_retries_r1 (`a` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test/02456_keeper_retries_during_insert', 'r1') ORDER BY tuple() SETTINGS index_granularity = 8327, min_bytes_for_wide_part = 1051395083, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 481563441, compact_parts_max_granules_to_buffer = 35, compact_parts_merge_max_bytes_to_prefetch_part = 24238977, merge_max_block_size = 18731, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3668895814, index_granularity_bytes = 252653, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 5, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 38834, primary_key_compress_block_size = 14399, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:17:46.754433 [ 5803 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:17:47.130453 [ 16691 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:17:47.137540 [ 16691 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:17:48.131999 [ 17390 ] {0da0e5e1-3143-42ea-b795-f289edb8337d} executeQuery: Code: 43. DB::Exception: First parameter for aggregate function groupConcat should be string. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47662) (comment: 03156_group_concat.sql) (query 22, line 37) (in query: SELECT groupConcat(123)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:218: DB::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002132747d 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:17:48.138620 [ 17390 ] {} TCPHandler: Code: 43. DB::Exception: First parameter for aggregate function groupConcat should be string. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:218: DB::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002132747d 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:17:48.642135 [ 6078 ] {45bfc62f-39c3-4c11-845f-af6fbef71d77} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> (lambda(x) + 1) AS lambda. In scope x -> (lambda(x) + 1) AS lambda. (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56870) (comment: 02343_analyzer_lambdas.sql) (query 50, line 97) (in query: WITH x -> (lambda(x) + 1) AS lambda SELECT lambda(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2617: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000003049d082 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3181: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046b3ec 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2672: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000003049c304 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3181: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046b3ec 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:17:48.654656 [ 6078 ] {} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> (lambda(x) + 1) AS lambda. In scope x -> (lambda(x) + 1) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2617: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000003049d082 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3181: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046b3ec 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2672: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000003049c304 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3181: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046b3ec 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:17:48.711640 [ 6078 ] {cd164e55-1b47-4582-b745-cd0424809dcb} executeQuery: Code: 1. DB::Exception: Recursive lambda x -> (lambda1(x) + 1) AS lambda. In scope x -> (lambda1(x) + 1) AS lambda. (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56870) (comment: 02343_analyzer_lambdas.sql) (query 51, line 100) (in query: WITH x -> (lambda1(x) + 1) AS lambda, lambda AS lambda1 SELECT lambda(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2617: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000003049d082 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3181: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046b3ec 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2672: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000003049c304 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3181: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046b3ec 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:17:48.717789 [ 6078 ] {} TCPHandler: Code: 1. DB::Exception: Recursive lambda x -> (lambda1(x) + 1) AS lambda. In scope x -> (lambda1(x) + 1) AS lambda. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2617: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000003049d082 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3181: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046b3ec 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2672: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x000000003049c304 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3181: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046b3ec 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:17:48.799091 [ 16691 ] {347f506c-bd71-42c8-9d61-f2ab24bfba99} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected date: 2025-2-55: In scope SELECT parseDateTime64BestEffort('2.55'). (CANNOT_PARSE_DATETIME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48436) (comment: 01424_parse_date_time_bad_date.sql) (query 1, line 1) (in query: select parseDateTime64BestEffort('2.55');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned short&, unsigned short&&, unsigned short&&) @ 0x000000001fa543f7 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa22ab4 5. ./src/Functions/FunctionsConversion.h:979: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0fc63e 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0c3aa9 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:17:48.806698 [ 16691 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected date: 2025-2-55: In scope SELECT parseDateTime64BestEffort('2.55'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned short&, unsigned short&&, unsigned short&&) @ 0x000000001fa543f7 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTime64BestEffort(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa22ab4 5. ./src/Functions/FunctionsConversion.h:979: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0fc63e 6. ./src/Functions/FunctionsConversion.h:2677: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0c3aa9 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:17:48.845026 [ 16186 ] {2ac5f849-2174-4419-87dc-6bc22c8e7cb8} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.13 MiB (attempt to allocate chunk of 1.12 MiB), maximum: 9.31 GiB: while executing 'FUNCTION modulo(plus(modulo(__table1.number, 2_UInt8), modulo(__table1.number, 3_UInt8)) :: 2, 2_UInt8 :: 1) -> modulo(plus(modulo(__table1.number, 2_UInt8), modulo(__table1.number, 3_UInt8)), 2_UInt8) UInt8 : 5'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40222) (comment: 01300_group_by_other_keys.sql) (query 3, line 5) (in query: SELECT round(max(log(2) * number), 6) AS k FROM numbers(10000000) GROUP BY number % 2, number % 3, (number % 2 + number % 3) % 2 ORDER BY k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 10. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000156133f6 11. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000015612590 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000015610966 13. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000155e0285 14. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000155d6bb2 15. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000155d116d 16. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000155ced6d 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:17:48.866703 [ 16186 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.13 MiB (attempt to allocate chunk of 1.12 MiB), maximum: 9.31 GiB: while executing 'FUNCTION modulo(plus(modulo(__table1.number, 2_UInt8), modulo(__table1.number, 3_UInt8)) :: 2, 2_UInt8 :: 1) -> modulo(plus(modulo(__table1.number, 2_UInt8), modulo(__table1.number, 3_UInt8)), 2_UInt8) UInt8 : 5'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 10. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000156133f6 11. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000015612590 12. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000015610966 13. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000155e0285 14. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000155d6bb2 15. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000155d116d 16. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000155ced6d 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 21. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 22. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:17:49.684766 [ 16355 ] {aed83658-2d35-433a-8b22-fd575e454687} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48580) (comment: 03247_create-same-table-concurrently-with-atomic-engine.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_5_db SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:17:49.694506 [ 16355 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:17:49.914229 [ 17390 ] {5b7c52c8-513b-4c8a-93cd-0318cac7648d} executeQuery: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47662) (comment: 03156_group_concat.sql) (query 23, line 38) (in query: SELECT groupConcat(',', '3')(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:227: DB::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000213275e3 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:17:49.921562 [ 17390 ] {} TCPHandler: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:227: DB::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000213275e3 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:17:51.079359 [ 17390 ] {d43bb3c4-19cc-4da7-9551-005d33ee84cc} executeQuery: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number, got: 0. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47662) (comment: 03156_group_concat.sql) (query 24, line 39) (in query: SELECT groupConcat(',', 0)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, long const&) @ 0x0000000021327ded 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:231: DB::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000021326fc9 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:17:51.085754 [ 17390 ] {} TCPHandler: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number, got: 0. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, long const&) @ 0x0000000021327ded 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:231: DB::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000021326fc9 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:17:51.126506 [ 17390 ] {09830000-79fa-48fa-b0d3-f1e20fa6ca24} executeQuery: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number, got: -1. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47662) (comment: 03156_group_concat.sql) (query 25, line 40) (in query: SELECT groupConcat(',', -1)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, long const&) @ 0x0000000021327ded 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:231: DB::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000021326fc9 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:17:51.134103 [ 17390 ] {} TCPHandler: Code: 36. DB::Exception: Second parameter for aggregate function groupConcat should be a positive number, got: -1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, long const&) @ 0x0000000021327ded 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:231: DB::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000021326fc9 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:17:52.206240 [ 17390 ] {812decc2-fa1a-4d95-b09f-7a433e194492} executeQuery: Code: 34. DB::Exception: Incorrect number of parameters for aggregate function groupConcat, should be 0, 1 or 2, got: 3. (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47662) (comment: 03156_group_concat.sql) (query 26, line 41) (in query: SELECT groupConcat(',', 3, 3)(number) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000ae9cd6d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:211: DB::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000021327309 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:17:52.211749 [ 17390 ] {} TCPHandler: Code: 34. DB::Exception: Incorrect number of parameters for aggregate function groupConcat, should be 0, 1 or 2, got: 3. (TOO_MANY_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000000ae9cd6d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupConcat.cpp:211: DB::createAggregateFunctionGroupConcat(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000021327309 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:17:58.681528 [ 18096 ] {423ffcb9-239c-45a8-b69c-e1ef6c97eb43} executeQuery: Code: 63. DB::Exception: Aggregate function with name 'abs' does not exist. In scope SELECT number, abs(number) OVER (PARTITION BY toString(intDiv(number, 3)) ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(10). (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 8, line 19) (in query: -- not a window function select number, abs(number) over (partition by toString(intDiv(number, 3)) rows unbounded preceding) from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000278ac8d7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3272: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003047aaac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:58.711897 [ 18096 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function with name 'abs' does not exist. In scope SELECT number, abs(number) OVER (PARTITION BY toString(intDiv(number, 3)) ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(10). (UNKNOWN_AGGREGATE_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000278ac8d7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3272: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003047aaac 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:17:59.517942 [ 16354 ] {c9221bb3-58fd-47dc-87f7-1b1aeaf7adcc} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'EMPTY'. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47378) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b EMPTY as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1690: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1d9404 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1df26f 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235bdf 9. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 10. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 11. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 12. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 13. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 14. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:17:59.521545 [ 16354 ] {c9221bb3-58fd-47dc-87f7-1b1aeaf7adcc} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'EMPTY'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1690: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1d9404 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1df26f 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235bdf 9. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 10. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 11. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 12. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 13. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 14. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:00.866660 [ 16354 ] {cf92d274-79c7-4464-bd5b-bad0dc1391cc} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'POPULATE'. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47394) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b POPULATE as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1684: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1d8f51 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1df26f 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235bdf 9. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 10. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 11. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 12. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 13. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 14. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:18:00.870236 [ 16354 ] {cf92d274-79c7-4464-bd5b-bad0dc1391cc} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'POPULATE'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1684: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1d8f51 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1df26f 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235bdf 9. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 10. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 11. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 12. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 13. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 14. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:01.095936 [ 17383 ] {c304c7c7-9118-4849-b71d-efc24ac9562e} executeQuery: Code: 69. DB::Exception: Too large parameter(s) for aggregate function 'topKWeighted' (maximum is 16777215). (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34946) (comment: 01471_top_k_range_check.sql) (query 1, line 1) (in query: SELECT length(topKWeighted(2, -9223372036854775808)(number, 1025)) FROM system.numbers;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:506: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025378c25 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:18:01.148938 [ 17383 ] {} TCPHandler: Code: 69. DB::Exception: Too large parameter(s) for aggregate function 'topKWeighted' (maximum is 16777215). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:506: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionTopK(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000025378c25 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:18:02.539884 [ 18391 ] {02181827-e9b5-4e2d-8eeb-013934f61c26} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'ENGINE'. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49450) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa TO b ENGINE = MergeTree() as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1680: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1d8e11 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1df26f 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235bdf 9. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 10. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 11. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 12. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 13. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 14. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:18:02.555469 [ 18391 ] {02181827-e9b5-4e2d-8eeb-013934f61c26} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'TO [db].[table]' and 'ENGINE'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1680: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1d8e11 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1df26f 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235bdf 9. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 10. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 11. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 12. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 13. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 14. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.201971 [ 5803 ] {edfb499e-b640-403a-91f7-de5176d6dfba} executeQuery: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'ENGINE' and 'TO [db].[table]'. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49466) (comment: 02900_matview_create_to_errors.sh) (in query: create materialized view aaaa ENGINE = MergeTree() TO b as Select * from a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1674: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1d92ce 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1df26f 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235bdf 9. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 10. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 11. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 12. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 13. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 14. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:18:04.205639 [ 5803 ] {edfb499e-b640-403a-91f7-de5176d6dfba} DynamicQueryHandler: Code: 62. DB::Exception: When creating a materialized view you can't declare both 'ENGINE' and 'TO [db].[table]'. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1674: DB::ParserCreateViewQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1d92ce 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserCreateQuery.cpp:1967: DB::ParserCreateQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e1df26f 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:86: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235bdf 9. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 10. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 11. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 12. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 13. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 14. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 17. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 18. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.549185 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 828.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.551804 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 828.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.702611 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 819.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.703324 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 819.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.716527 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 818.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.717251 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 818.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.889024 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 811.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.889871 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 811.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.975144 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 811.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:04.985201 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 811.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:05.108130 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 811.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.53 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:05.145273 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 811.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.53 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:05.164823 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 807.55 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.52 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:05.165443 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 807.55 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.52 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:05.416514 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 800.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:05.417184 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 800.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.186792 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 801.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.70 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.187540 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 801.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.70 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.249451 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 801.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.81 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.250148 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 801.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.81 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.310845 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.311695 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.314417 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.317406 [ 18112 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.318135 [ 18112 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.319093 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.324574 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.325052 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.334655 [ 18112 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.335329 [ 18112 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.336953 [ 18112 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.337496 [ 18112 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.350283 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.350955 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.353270 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.356943 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.94 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.366045 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.96 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.366684 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.96 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.408442 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.99 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.409088 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.99 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.447966 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.99 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.448930 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.99 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.486286 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.86 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.487042 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.86 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.498937 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.86 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.499543 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.86 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.531647 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.67 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.532435 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.67 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.542478 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.67 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.543114 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.67 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.559220 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.559974 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.600671 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.601447 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.633359 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.634054 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.647951 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.648632 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.684971 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.685501 [ 18112 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.685779 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.686458 [ 18112 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.688399 [ 16189 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.689128 [ 16189 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.704006 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.704813 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.704847 [ 16690 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.705496 [ 16690 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.706288 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.717094 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.722794 [ 16054 ] {b2bae212-ab21-4096-8632-7019946bb846} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 829.44 MiB (attempt to allocate chunk of 1.13 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48360) (comment: 01451_dist_logs.sh) (query 14, line 14) (in query: select * from remote('127.{2,3}', system.numbers) where number = 10 limit 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9c535 14. ./build_docker/./src/Client/Connection.cpp:1060: DB::Connection::sendScalarsData(std::map, std::allocator>>&) @ 0x000000003aa9f1e4 15. ./build_docker/./src/Client/HedgedConnections.cpp:108: DB::HedgedConnections::sendScalarsData(std::map, std::allocator>>&) @ 0x000000003ab2e580 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:866: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278240 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 18. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 19. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 20. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:18:06.767435 [ 18112 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.768222 [ 18112 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.801618 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.802382 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 803.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.807754 [ 15982 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52032, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.808401 [ 15982 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52032, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.838485 [ 16054 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 829.44 MiB (attempt to allocate chunk of 1.13 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9c535 14. ./build_docker/./src/Client/Connection.cpp:1060: DB::Connection::sendScalarsData(std::map, std::allocator>>&) @ 0x000000003aa9f1e4 15. ./build_docker/./src/Client/HedgedConnections.cpp:108: DB::HedgedConnections::sendScalarsData(std::map, std::allocator>>&) @ 0x000000003ab2e580 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:866: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278240 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 18. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 19. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 20. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:18:06.871559 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 797.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.28 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.872505 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 797.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.28 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.964520 [ 16189 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 805.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.965197 [ 16189 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 805.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:06.980535 [ 16230 ] {a31bd02d-3c14-4b6b-9e06-d099d79bfdd5} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:37424). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x000000003aea5649 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.005226 [ 16189 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 801.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.005893 [ 16189 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 801.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.017133 [ 17752 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 800.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.017785 [ 17752 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 800.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.020547 [ 16189 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 799.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.021049 [ 16189 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 799.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.045325 [ 16189 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 795.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.046066 [ 16189 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 795.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.094523 [ 16189 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 796.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.095253 [ 16189 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 796.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.111044 [ 16189 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 797.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.111643 [ 16189 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 797.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.137860 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_150_5} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 828.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.139152 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_150_5}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 828.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.171918 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 797.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.416014 [ 17752 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 799.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.416742 [ 17752 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 799.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.519303 [ 16189 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 796.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.519958 [ 16189 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 796.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.524270 [ 16189 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 796.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.524841 [ 16189 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 796.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.621022 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_79_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 812.11 MiB (attempt to allocate chunk of 2.00 MiB bytes), current RSS: 15.52 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c3f 12. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:47: DB::CompressedWriteBuffer::nextImpl() @ 0x000000003dd3a5a7 13. DB::WriteBuffer::next() @ 0x0000000008c37ea1 14. ./src/IO/HashingWriteBuffer.h:63: DB::HashingWriteBuffer::nextImpl() @ 0x000000003952910e 15. DB::WriteBuffer::next() @ 0x0000000008c37ea1 16. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e2755 18. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:522: DB::SerializationLowCardinality::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f698e79 19. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:73: DB::SerializationNamed::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f6c07ec 20. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:763: DB::SerializationTuple::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f7e8f92 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 22. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:463: DB::SerializationMap::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f6b6f41 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:434: DB::MergeTreeDataPartWriterWide::writeSingleGranule(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::shared_ptr&, DB::ISerialization::SerializeBinaryBulkSettings&, DB::Granule const&) @ 0x0000000039be9bc7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:498: DB::MergeTreeDataPartWriterWide::writeColumn(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::vector> const&) @ 0x0000000039be6529 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:343: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039be1a84 26. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.622582 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_79_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 812.11 MiB (attempt to allocate chunk of 2.00 MiB bytes), current RSS: 15.52 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c3f 12. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:47: DB::CompressedWriteBuffer::nextImpl() @ 0x000000003dd3a5a7 13. DB::WriteBuffer::next() @ 0x0000000008c37ea1 14. ./src/IO/HashingWriteBuffer.h:63: DB::HashingWriteBuffer::nextImpl() @ 0x000000003952910e 15. DB::WriteBuffer::next() @ 0x0000000008c37ea1 16. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:212: DB::SerializationNumber::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f6e2755 18. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:522: DB::SerializationLowCardinality::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f698e79 19. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:73: DB::SerializationNamed::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f6c07ec 20. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:763: DB::SerializationTuple::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f7e8f92 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 22. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:463: DB::SerializationMap::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f6b6f41 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:434: DB::MergeTreeDataPartWriterWide::writeSingleGranule(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::shared_ptr&, DB::ISerialization::SerializeBinaryBulkSettings&, DB::Granule const&) @ 0x0000000039be9bc7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:498: DB::MergeTreeDataPartWriterWide::writeColumn(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::vector> const&) @ 0x0000000039be6529 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:343: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039be1a84 26. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:07.989061 [ 3903 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryLogElement]: Failed to flush system log system.query_log with 691 entries up to offset 41524: Code: 241. DB::Exception: (total) memory limit exceeded: would use 816.70 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x00000000091ef3f0 10. ./build_docker/./src/Columns/ColumnArray.cpp:947: COW::immutable_ptr DB::ColumnArray::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000370bb2ab 11. ./src/Columns/ColumnsCommon.h:136: DB::ColumnArray::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000370ab628 12. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:47: DB::permuteBlockIfNeeded(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039829bfb 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:189: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba572d 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 26. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332cf2e1 27. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x00000000332cc91e 28. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fb9ba81 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fb9b8bf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.578187 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 619.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.579001 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 619.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.581018 [ 2996 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 619.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.581791 [ 2996 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 619.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.614606 [ 2996 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 618.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.615231 [ 2996 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 618.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.623410 [ 2996 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 614.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.623974 [ 2996 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 614.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.663920 [ 2996 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 613.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.664566 [ 2996 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 613.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.696137 [ 2996 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 596.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.696842 [ 2996 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 596.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.714405 [ 2996 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 594.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.715047 [ 2996 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 594.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.726151 [ 2996 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 589.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.726818 [ 2996 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 589.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.743786 [ 2996 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 589.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.744416 [ 2996 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 589.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.823235 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 574.07 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.824010 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 574.07 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.824518 [ 17376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 574.07 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.825193 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 574.07 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.850936 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.851752 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.852204 [ 17376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.852956 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.861570 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:08.862213 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.231753 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 496.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.47 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.232588 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 496.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.47 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.252284 [ 17653 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 495.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.260485 [ 17653 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 495.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.282068 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.56 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.282782 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.56 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.285233 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.56 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.285822 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.56 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.299270 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.56 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.299948 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.56 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.302666 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.56 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.303235 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.56 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.306152 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 481.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.55 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.307072 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 481.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.55 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.310505 [ 16323 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 480.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.55 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.311350 [ 16323 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 480.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.55 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.332778 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.35 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.59 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.333461 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.35 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.59 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.366825 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 475.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.59 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.367640 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 475.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.59 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.391465 [ 16390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 474.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.392330 [ 16390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 474.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.397613 [ 16235 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 467.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.398375 [ 16235 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 467.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.405253 [ 18722 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.406046 [ 18722 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.801562 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.802242 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.806989 [ 16390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 466.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:09.813835 [ 16390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 466.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.234879 [ 16235 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 487.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.235484 [ 18131 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 487.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.235774 [ 16235 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 487.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.236573 [ 18131 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 487.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.240749 [ 16390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 486.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.241354 [ 16390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 486.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.260779 [ 19621 ] {f5cf8f91-2e64-487a-b795-4bf489471c67} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34292) (comment: 01814_distributed_push_down_limit.sh) (query 2, line 3) (in query: select read_rows from system.query_log where event_date >= yesterday() and query_kind = 'Select' /* exclude DESC TABLE */ and type = 'QueryFinish' and initial_query_id = 'wnzarazwdx-test_seedzr1x' and initial_query_id != query_id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:828: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039c3bc0b 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1866: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c2aea5b 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1572: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c2aa6a2 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1567: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c2a9e37 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2055: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c2c0e58 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2163: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c795c 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:18:11.270218 [ 18131 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.270935 [ 18131 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.311596 [ 19621 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:828: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039c3bc0b 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1866: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c2aea5b 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1572: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003c2aa6a2 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1567: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003c2a9e37 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2055: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003c2c0e58 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2163: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c795c 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:18:11.317760 [ 18403 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.318556 [ 18131 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 483.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.318760 [ 18403 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.319545 [ 18131 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 483.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.322994 [ 16702 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 481.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.323610 [ 16702 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 481.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.343640 [ 18131 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.344310 [ 18131 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.357758 [ 18131 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.358382 [ 18131 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.793179 [ 16223 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.793913 [ 16223 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.825433 [ 16223 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.826112 [ 16223 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.842761 [ 16223 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.843973 [ 16223 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.873574 [ 16223 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.874226 [ 16223 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.892601 [ 16889 ] {aaf2745d-68ec-40c0-badf-3e56bdd32877} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 816.56 MiB (attempt to allocate chunk of 1.38 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while converting source column `if(equals(modulo(number, 3), 0), NULL, number)` to destination column a: while executing 'FUNCTION _CAST(if(equals(modulo(number, 3), 0), NULL, number) :: 0, LowCardinality(Nullable(Float64)) :: 1) -> _CAST(if(equals(modulo(number, 3), 0), NULL, number), LowCardinality(Nullable(Float64))) LowCardinality(Nullable(Float64)) : 2'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34778) (comment: 00751_low_cardinality_nullable_group_by.sql) (query 4, line 4) (in query: INSERT INTO low_null_float (a) SELECT if(number % 3 == 0, Null, number) FROM system.numbers LIMIT 1000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. ./src/Common/HashTable/HashTable.h:538: HashTable, true>, DB::ColumnVector, false, true>, DB::ReverseIndexHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x00000000379be531 12. ./src/Common/HashTable/HashTable.h:926: DB::ReverseIndex>::insert(StringRef) @ 0x00000000378656ea 13. ./src/Columns/ColumnUnique.h:602: COW::mutable_ptr DB::ColumnUnique>::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex>*, unsigned long) @ 0x00000000379c072e 14. ./src/Columns/ColumnUnique.h:569: COW::mutable_ptr DB::ColumnUnique>::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex>*, unsigned long)::'lambda'(unsigned long&)::operator()(unsigned long&) const @ 0x00000000379bf631 15. ./src/Columns/ColumnUnique.h:605: COW::mutable_ptr DB::ColumnUnique>::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex>*, unsigned long) @ 0x00000000379bb141 16. ./src/Columns/ColumnUnique.h:653: COW::mutable_ptr DB::ColumnUnique>::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long)::'lambda'(auto)::operator()(auto) const @ 0x0000000037861181 17. ./src/Columns/ColumnUnique.h:661: DB::ColumnUnique>::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037860794 18. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:227: DB::ColumnLowCardinality::insertRangeFromFullColumn(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003753ed24 19. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c9334c3 20. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c932084 21. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 23. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 24. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 25. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 26. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 27. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 28. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 2025.11.13 09:18:11.937106 [ 16223 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.50 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:11.937965 [ 16223 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.50 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:12.045972 [ 16352 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:12.046628 [ 16352 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:12.052747 [ 16352 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:12.061095 [ 16352 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:12.283090 [ 16889 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 816.56 MiB (attempt to allocate chunk of 1.38 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while converting source column `if(equals(modulo(number, 3), 0), NULL, number)` to destination column a: while executing 'FUNCTION _CAST(if(equals(modulo(number, 3), 0), NULL, number) :: 0, LowCardinality(Nullable(Float64)) :: 1) -> _CAST(if(equals(modulo(number, 3), 0), NULL, number), LowCardinality(Nullable(Float64))) LowCardinality(Nullable(Float64)) : 2'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. ./src/Common/HashTable/HashTable.h:538: HashTable, true>, DB::ColumnVector, false, true>, DB::ReverseIndexHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x00000000379be531 12. ./src/Common/HashTable/HashTable.h:926: DB::ReverseIndex>::insert(StringRef) @ 0x00000000378656ea 13. ./src/Columns/ColumnUnique.h:602: COW::mutable_ptr DB::ColumnUnique>::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex>*, unsigned long) @ 0x00000000379c072e 14. ./src/Columns/ColumnUnique.h:569: COW::mutable_ptr DB::ColumnUnique>::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex>*, unsigned long)::'lambda'(unsigned long&)::operator()(unsigned long&) const @ 0x00000000379bf631 15. ./src/Columns/ColumnUnique.h:605: COW::mutable_ptr DB::ColumnUnique>::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex>*, unsigned long) @ 0x00000000379bb141 16. ./src/Columns/ColumnUnique.h:653: COW::mutable_ptr DB::ColumnUnique>::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long)::'lambda'(auto)::operator()(auto) const @ 0x0000000037861181 17. ./src/Columns/ColumnUnique.h:661: DB::ColumnUnique>::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037860794 18. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:227: DB::ColumnLowCardinality::insertRangeFromFullColumn(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003753ed24 19. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c9334c3 20. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c932084 21. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 22. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 23. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 24. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 25. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 26. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 27. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 28. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:18:13.459967 [ 16693 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.460796 [ 16693 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.495402 [ 17268 ] {c5ff4927-9e6e-471e-a922-061a38036e8e} executeQuery: Code: 60. DB::Exception: Table `test_shcayy9j`.`table_for_renames42` doesn't exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37728) (comment: 01508_race_condition_rename_clear_zookeeper_long.sh) (query 1, line 1) (in query: RENAME TABLE table_for_renames42 TO table_for_renames43), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:536: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002fa8a408 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f8b4925 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:156: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032affeb4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:13.525794 [ 16693 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.526592 [ 16693 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.537952 [ 17268 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_shcayy9j`.`table_for_renames42` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:536: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002fa8a408 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f8b4925 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:156: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032affeb4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:13.564331 [ 16446 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.565081 [ 16446 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.565670 [ 16693 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.566483 [ 16693 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.578408 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.579422 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.602077 [ 16199 ] {250dae3a-ad5a-4675-b601-85d4b9c9bb7a} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 10.23 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54878) (comment: 02574_suspicious_low_cardinality_msan.sql) (query 4, line 5) (in query: INSERT INTO table1__fuzz_19 SELECT number - 205, number FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 2025.11.13 09:18:13.639499 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.640153 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.686294 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.686950 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.687087 [ 16446 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.687774 [ 16446 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.761425 [ 16199 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 10.23 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:18:13.955101 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_150_5} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:13.964843 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_150_5}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.301711 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.302407 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.527340 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.528092 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.560795 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.564994 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.594367 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.595314 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.619073 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.619789 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.635794 [ 4028 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.664658 [ 4028 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.668135 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.668843 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.673273 [ 17226 ] {ba1494fb-f69f-4a1f-bf09-c1dfe60015ea} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37592) (comment: 00220_shard_with_totals_in_subquery_remote_and_limit.sql) (query 2, line 4) (in query: SELECT x FROM (SELECT count() AS x FROM remote('127.0.0.2') WITH TOTALS) LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 13. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 14. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 15. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac820b 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa75bc6 17. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 18. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:18:14.675286 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.675911 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.678309 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.679011 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:14.710184 [ 17226 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 13. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 14. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 15. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac820b 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa75bc6 17. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 18. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:18:15.653820 [ 18106 ] {d23b82e4-0fe4-4278-ad3e-0e130e54e508} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 443.22 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54944) (comment: 02521_aggregation_by_partitions.sql) (query 12, line 19) (in query: insert into t1 select number from numbers_mt(1e6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037b0e38e 12. ./build_docker/./src/Columns/IColumn.cpp:254: DB::IColumnHelper, DB::ColumnFixedSizeHelper>::scatter(unsigned long, DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003818ebd8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:369: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7bce0 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:18:15.759008 [ 18106 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 443.22 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037b0e38e 12. ./build_docker/./src/Columns/IColumn.cpp:254: DB::IColumnHelper, DB::ColumnFixedSizeHelper>::scatter(unsigned long, DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003818ebd8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:369: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7bce0 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:18:16.214837 [ 19618 ] {cdb2db2a-f6dc-4597-9532-1340b1605b5e} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38324) (comment: 02597_column_update_tricky_expression_and_replication.sql) (query 2, line 7) (in query: CREATE TABLE test (`c_id` String, `p_id` String, `d` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test/test_table', '1') ORDER BY (c_id, p_id) SETTINGS index_granularity = 10778, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 117, min_bytes_for_full_part_storage = 83699564, compact_parts_max_bytes_to_buffer = 230816212, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 11749793, merge_max_block_size = 22229, old_parts_lifetime = 390., prefer_fetch_merged_part_size_threshold = 9318531001, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 46, min_merge_bytes_to_use_direct_io = 2069944870, index_granularity_bytes = 6402351, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 40385, primary_key_compress_block_size = 15215, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:18:16.220945 [ 19618 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:18:16.524302 [ 16054 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 472.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.525229 [ 16054 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 472.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.532717 [ 18824 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 472.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.532717 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 472.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.533460 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 472.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.532759 [ 3736 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_85_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 472.60 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.556610 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_85_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 472.60 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.590853 [ 16054 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 471.61 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.591573 [ 16054 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 471.61 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.738458 [ 16054 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.739198 [ 16054 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.889388 [ 3739 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_151_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.93 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:16.891004 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_151_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.93 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:17.212555 [ 3912 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryMetricLogElement]: Failed to flush system log system.query_metric_log with 65 entries up to offset 3952: Code: 241. DB::Exception: (total) memory limit exceeded: would use 474.66 MiB (attempt to allocate chunk of 4.05 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000333e0dcc (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:18.187961 [ 16054 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:18.188642 [ 16054 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:18.211946 [ 3727 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_152_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:18.238435 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_152_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:18.313711 [ 3245 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1403: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x0000000031b06d66 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1425: DB::DatabaseCatalog::dropTableDataTask() @ 0x0000000031b07f49 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:219: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x0000000031b2b7df 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:18.636007 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 471.66 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:18.648571 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 471.66 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:19.142092 [ 18112 ] {2443ac1c-8a78-4c02-85c1-8a1ff9bc384d} executeQuery: Code: 60. DB::Exception: Table `test_shcayy9j`.`table_for_renames44` doesn't exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38796) (comment: 01508_race_condition_rename_clear_zookeeper_long.sh) (query 1, line 1) (in query: RENAME TABLE table_for_renames44 TO table_for_renames45), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:536: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002fa8a408 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f8b4925 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:156: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032affeb4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:19.186844 [ 18112 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_shcayy9j`.`table_for_renames44` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:536: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002fa8a408 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f8b4925 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:156: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032affeb4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:20.036659 [ 18403 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.037328 [ 18403 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.047945 [ 18403 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.048568 [ 18403 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.068497 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.069125 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.120112 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.120808 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.534463 [ 16323 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.535105 [ 16323 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.553183 [ 16323 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.553812 [ 16323 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.591093 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_152_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.593553 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_152_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.612826 [ 16323 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.68 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.613489 [ 16323 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.68 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.811549 [ 16390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.72 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:20.819115 [ 16390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.72 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:21.182274 [ 16690 ] {2f31c0a0-2dbc-4a44-9081-acd3fb16939c} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(257)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38778) (comment: 02426_create_suspicious_fixed_string.sql) (query 2, line 2) (in query: CREATE TABLE suspicious_fixed_string (`id` UInt64, `s` FixedString(257)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 31145, min_bytes_for_wide_part = 359338090, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 519014520, compact_parts_max_granules_to_buffer = 225, compact_parts_merge_max_bytes_to_prefetch_part = 23357768, merge_max_block_size = 16098, old_parts_lifetime = 284., prefer_fetch_merged_part_size_threshold = 8151629510, vertical_merge_algorithm_min_rows_to_activate = 211355, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7721379920, index_granularity_bytes = 6874253, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 27707, primary_key_compress_block_size = 46247, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000098c9f8d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033936513 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000033933dfb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000329e83d5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d9589 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:18:21.210823 [ 18824 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:21.232296 [ 16690 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(257)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x00000000098c9f8d 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000033936513 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000033933dfb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000329e83d5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d9589 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:18:22.559542 [ 17268 ] {b87478c1-db5e-4e21-ad1f-ee86e152d0c7} executeQuery: Code: 60. DB::Exception: Table `test_shcayy9j`.`table_for_renames45` doesn't exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48442) (comment: 01508_race_condition_rename_clear_zookeeper_long.sh) (query 1, line 1) (in query: RENAME TABLE table_for_renames45 TO table_for_renames46), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:536: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002fa8a408 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f8b4925 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:156: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032affeb4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:22.591114 [ 17268 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_shcayy9j`.`table_for_renames45` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:536: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002fa8a408 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f8b4925 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:156: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032affeb4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:22.809090 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 544.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:22.809739 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 544.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:22.875889 [ 3732 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_152_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 540.32 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_135_145_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9362): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:22.877183 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_152_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 540.32 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_135_145_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9362): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:22.877425 [ 16200 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 540.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:22.878111 [ 16200 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 540.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:22.879620 [ 16200 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 540.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:22.880150 [ 16200 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 540.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:22.889160 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 12 entries up to offset 1185: Code: 241. DB::Exception: (total) memory limit exceeded: would use 541.74 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:22.937272 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 508.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:22.937968 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 508.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.423364 [ 16691 ] {7282854e-b839-474d-8102-6ca502f6d9ff} executeQuery: Code: 43. DB::Exception: Elements of array of second argument of function roundDown must be numeric type.: In scope SELECT 1 AS x, roundDown(x, []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38410) (comment: 00805_round_down.sql) (query 7, line 8) (in query: SELECT 1 as x, roundDown(x, []);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionRoundDown::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000acc2e19 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:18:23.457136 [ 16691 ] {} TCPHandler: Code: 43. DB::Exception: Elements of array of second argument of function roundDown must be numeric type.: In scope SELECT 1 AS x, roundDown(x, []). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionRoundDown::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000acc2e19 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:18:23.681148 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.688971 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.711458 [ 16446 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.712143 [ 16446 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.740490 [ 18131 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.786563 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.788928 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.808381 [ 3734 ] {5a642d2d-8981-43c6-8ee1-d369be3bbe53::202511_1_101_20} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.55 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.828473 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5a642d2d-8981-43c6-8ee1-d369be3bbe53::202511_1_101_20}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.55 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.835660 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.55 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.836567 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.55 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.879150 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.879713 [ 16446 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.885591 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.886163 [ 16693 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.886900 [ 16693 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.888797 [ 16446 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.902847 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 449.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.903561 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 449.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.922170 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:23.922737 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:25.195593 [ 18131 ] {} DynamicQueryHandler: Cannot send exception to client: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./build_docker/./src/Server/HTTPHandler.cpp:623: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace72e6 14. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:25.261582 [ 16446 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 471.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:25.262258 [ 16446 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 471.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:25.263088 [ 4028 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 471.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:25.263729 [ 4028 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 471.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:25.270304 [ 16446 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:25.270885 [ 16446 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:25.447789 [ 3724 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_153_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 477.04 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:25.449155 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_153_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 477.04 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.200640 [ 18391 ] {b8ed0c97-f16a-4887-b672-3019f1392913} executeQuery: Code: 60. DB::Exception: Table `test_shcayy9j`.`table_for_renames46` doesn't exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48964) (comment: 01508_race_condition_rename_clear_zookeeper_long.sh) (query 1, line 1) (in query: RENAME TABLE table_for_renames46 TO table_for_renames47), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:536: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002fa8a408 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f8b4925 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:156: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032affeb4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:26.235059 [ 18391 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_shcayy9j`.`table_for_renames46` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:536: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002fa8a408 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f8b4925 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:156: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032affeb4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:26.271636 [ 3739 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.300533 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.437591 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.438221 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.459831 [ 19619 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.469513 [ 19619 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.480557 [ 16691 ] {09887164-db22-42a0-a5d5-2a8e32c6ddae} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38410) (comment: 00805_round_down.sql) (query 8, line 9) (in query: SELECT 1 as x, roundDown(x, emptyArrayUInt8());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14508e 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 13. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:18:26.496263 [ 16691 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14508e 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 13. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:18:26.507073 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_153_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.04 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.508384 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_153_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.04 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.513808 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.514506 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.633360 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.634024 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.798683 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.802641 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.803318 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.805261 [ 16691 ] {fc861ac6-cbde-493d-865a-c0293d0906f3} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38410) (comment: 00805_round_down.sql) (query 9, line 10) (in query: SELECT roundDown(number, [number]) FROM system.numbers LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14508e 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 13. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:18:26.805675 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.805899 [ 19619 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.806276 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.806976 [ 19619 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.809181 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.809667 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.838956 [ 16691 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14508e 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 13. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:18:26.858250 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:26.858883 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:28.677546 [ 15982 ] {50052698-66ce-4c2f-8ba9-54335870461f} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49280) (comment: 01513_count_without_select_sequence_consistency_zookeeper_long.sql) (query 5, line 10) (in query: CREATE TABLE quorum1 (`x` UInt32, `y` Date) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01513/sequence_consistency', '1') PARTITION BY y ORDER BY x SETTINGS index_granularity = 15153, min_bytes_for_wide_part = 858172806, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 41, min_bytes_for_full_part_storage = 41087089, compact_parts_max_bytes_to_buffer = 102693621, compact_parts_max_granules_to_buffer = 121, compact_parts_merge_max_bytes_to_prefetch_part = 11275377, merge_max_block_size = 17893, old_parts_lifetime = 403., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 765008, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 5625309575, index_granularity_bytes = 13540973, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 87, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 31174, primary_key_compress_block_size = 83520, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:18:28.703052 [ 15982 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:18:28.767367 [ 16200 ] {b66dce5b-635d-4575-9b22-9ab24cd4ffbc} executeQuery: Code: 57. DB::Exception: Table test_9.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48746) (comment: 02933_paste_join.sql) (query 9, line 9) (in query: CREATE TABLE t1 (a UInt64, b UInt64) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:18:28.777768 [ 16200 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:18:28.853198 [ 18392 ] {033a7f51-f36e-498d-80fd-50bbfd9f2a21} executeQuery: Code: 60. DB::Exception: Table `test_shcayy9j`.`table_for_renames47` doesn't exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49426) (comment: 01508_race_condition_rename_clear_zookeeper_long.sh) (query 1, line 1) (in query: RENAME TABLE table_for_renames47 TO table_for_renames48), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:536: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002fa8a408 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f8b4925 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:156: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032affeb4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:28.870158 [ 18392 ] {} TCPHandler: Code: 60. DB::Exception: Table `test_shcayy9j`.`table_for_renames47` doesn't exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/DatabasesCommon.cpp:536: DB::DatabaseWithOwnTablesBase::getTableUnlocked(String const&) const @ 0x000000002fa8a408 5. ./build_docker/./src/Databases/DatabaseAtomic.cpp:297: DB::DatabaseAtomic::renameTable(std::shared_ptr, String const&, DB::IDatabase&, String const&, bool, bool) @ 0x000000002f8b4925 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:156: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032affeb4 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:29.148700 [ 15982 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 479.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.149401 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 479.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.701585 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 493.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.702901 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 493.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.777635 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 479.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.778382 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 479.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.804272 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 479.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.805014 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 479.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.859609 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 477.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.860249 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 477.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.907031 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 443.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:29.907703 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 443.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:30.147395 [ 3729 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_153_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:30.148898 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_153_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:30.920867 [ 16691 ] {4808a343-3baa-4b02-9db3-f8def6771bed} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 467.46 MiB (attempt to allocate chunk of 5.35 MiB bytes), current RSS: 15.16 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38410) (comment: 00805_round_down.sql) (query 12, line 15) (in query: SELECT number % 10 as x, roundDown(x, (SELECT groupArray(number * 1.25) FROM numbers(100000))) FROM system.numbers LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. AllocatorWithMemoryTracking::allocate(unsigned long) @ 0x000000000aea8879 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:305: DB::ColumnArray::get(unsigned long, DB::Field&) const @ 0x000000003709963d 12. ./build_docker/./src/Columns/ColumnArray.cpp:131: DB::ColumnArray::operator[](unsigned long) const @ 0x0000000037099290 13. DB::FunctionRoundDown::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acbfa50 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 20. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 22. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 24. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 25. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:18:30.933167 [ 16691 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 467.46 MiB (attempt to allocate chunk of 5.35 MiB bytes), current RSS: 15.16 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. AllocatorWithMemoryTracking::allocate(unsigned long) @ 0x000000000aea8879 11. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:305: DB::ColumnArray::get(unsigned long, DB::Field&) const @ 0x000000003709963d 12. ./build_docker/./src/Columns/ColumnArray.cpp:131: DB::ColumnArray::operator[](unsigned long) const @ 0x0000000037099290 13. DB::FunctionRoundDown::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acbfa50 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 15. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 19. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 20. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 21. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 22. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 24. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 25. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:18:31.676033 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 14 entries up to offset 1199: Code: 241. DB::Exception: (total) memory limit exceeded: would use 468.51 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.677578 [ 18721 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.678293 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.689499 [ 18824 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.690131 [ 18824 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.707413 [ 18824 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.719889 [ 18824 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.719947 [ 2998 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.720664 [ 2998 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 464.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.765263 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 2264 entries up to offset 168535: Code: 241. DB::Exception: (total) memory limit exceeded: would use 467.59 MiB (attempt to allocate chunk of 4.18 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.852799 [ 19194 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:31.853538 [ 19194 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:32.287722 [ 19606 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:32.288438 [ 19606 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:32.299387 [ 19606 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:32.300058 [ 19606 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:32.320341 [ 19606 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:32.321123 [ 19606 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:32.337342 [ 19606 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:32.340978 [ 19606 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:32.359820 [ 19606 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.47 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:32.360438 [ 19606 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.47 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:33.738764 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.104988 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.123077 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.53 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.123724 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.53 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.143347 [ 2998 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.53 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.143953 [ 16199 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.144039 [ 2998 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.53 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.145360 [ 6072 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.148655 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.149241 [ 6072 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.150345 [ 16199 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.151460 [ 16233 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.152129 [ 16233 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.154081 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.154561 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.155306 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.161241 [ 2998 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.161878 [ 2998 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.164702 [ 6078 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.165137 [ 6078 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.57 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.193435 [ 2998 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.50 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.194141 [ 2998 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.50 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.265563 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.50 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.267085 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.50 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.927037 [ 3728 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_101_20} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:34.930263 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_101_20}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:35.014717 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_153_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:35.016227 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_135_153_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:36.605259 [ 18149 ] {e2551e02-55f8-4d24-b97e-b54eecf32a0b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'table_for_renames50' in scope SELECT COUNT() FROM table_for_renames50. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46700) (comment: 01508_race_condition_rename_clear_zookeeper_long.sh) (query 1, line 1) (in query: SELECT COUNT() from table_for_renames50), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:18:36.640181 [ 18149 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'table_for_renames50' in scope SELECT COUNT() FROM table_for_renames50. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:18:39.362784 [ 18096 ] {de2bf48e-96bd-4680-a246-78b18bbb1082} executeQuery: Code: 36. DB::Exception: The function 'lagInFrame' can only be used as a window function, not as an aggregate function. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 71, line 388) (in query: select lagInFrameOrNull(1) over ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::WindowFunction::fail() const @ 0x000000003bd2982e 4. ./src/AggregateFunctions/WindowFunction.h:81: ? @ 0x000000003bd261e9 5. ./src/AggregateFunctions/IAggregateFunction.h:552: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x000000003bd274c4 6. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:166: DB::AggregateFunctionOrFill::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000266b665c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1034: DB::WindowTransform::updateAggregationState() @ 0x000000003bd03f06 8. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1234: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06b68 9. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:18:39.434390 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: The function 'lagInFrame' can only be used as a window function, not as an aggregate function. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::WindowFunction::fail() const @ 0x000000003bd2982e 4. ./src/AggregateFunctions/WindowFunction.h:81: ? @ 0x000000003bd261e9 5. ./src/AggregateFunctions/IAggregateFunction.h:552: DB::IAggregateFunctionHelper::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x000000003bd274c4 6. ./src/AggregateFunctions/Combinators/AggregateFunctionOrFill.h:166: DB::AggregateFunctionOrFill::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000266b665c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1034: DB::WindowTransform::updateAggregationState() @ 0x000000003bd03f06 8. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1234: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06b68 9. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:18:40.537234 [ 18771 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 581.04 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:40.537953 [ 18771 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 581.04 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:40.624037 [ 3739 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 581.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:40.625336 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 581.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:42.440724 [ 18391 ] {5f48fc12-351c-4d71-8a12-7e04fe17f933} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38604) (comment: 03247_create-same-table-concurrently-with-atomic-engine.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_5_db SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a738e5 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:18:42.469873 [ 18391 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a738e5 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:18:43.620013 [ 18721 ] {96e0120d-3d8b-425a-bb8b-683e64ec10c4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38686) (comment: 02734_sparse_columns_short_circuit.sql) (query 5, line 11) (in query: SELECT sum(if(a % 10 = 0, CAST(b, 'UInt8'), 0)) FROM t_sparse_short_circuit;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:18:43.719135 [ 18721 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:18:44.576986 [ 18096 ] {6544d550-5a80-4e46-87cd-27bd92cb47d8} executeQuery: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], -1 given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 78, line 447) (in query: -- nth_value UBsan SELECT nth_value(1, -1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd38caf 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd3926d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:18:44.594267 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], -1 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd38caf 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd3926d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:18:44.653568 [ 2996 ] {d91ecd66-f05c-4742-83e9-3ed904cb9930} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40568) (comment: 02734_sparse_columns_short_circuit.sql) (in query: DROP DATABASE IF EXISTS test_995qcp08 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:18:44.658450 [ 2996 ] {d91ecd66-f05c-4742-83e9-3ed904cb9930} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:44.660708 [ 18096 ] {bcd0a5d5-02ae-4ac5-94d1-23511ac25b65} executeQuery: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], 0 given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 79, line 449) (in query: SELECT nth_value(1, 0) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd38caf 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd3926d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:18:44.671572 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], 0 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd38caf 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd3926d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:18:44.780228 [ 18096 ] {9a550280-91d5-4043-9c01-940b83e58d9f} executeQuery: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 80, line 450) (in query: SELECT nth_value(1, /* INT64_MAX+1 */ 0x7fffffffffffffff+1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd38caf 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd3926d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:18:44.826227 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function nth_value must be in (1, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2468: DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd38caf 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionNthValue::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd3926d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:18:46.429797 [ 18096 ] {bcc4cb95-f6e1-448c-b3b9-c4b9cd1f9ba6} executeQuery: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 83, line 454) (in query: -- lagInFrame UBsan SELECT lagInFrame(1, -1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd401f6 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd405ed 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:18:46.448186 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd401f6 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd405ed 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:18:46.698751 [ 18096 ] {8f749eb4-a8ea-4de5-a110-2e776b162075} executeQuery: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 85, line 457) (in query: SELECT lagInFrame(1, /* INT64_MAX+1 */ 0x7fffffffffffffff+1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd401f6 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd405ed 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:18:46.728590 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function lagInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd401f6 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd405ed 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:18:48.057367 [ 16703 ] {dfe2de39-f68f-459c-a9c3-ddb26d9b5dfd} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:218: DB::ConcurrentHashJoin::~ConcurrentHashJoin() @ 0x00000000327fdc8f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:67: std::__shared_ptr_emplace>::__on_zero_shared() @ 0x0000000031c24160 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:156: DB::ExpressionAnalysisResult::~ExpressionAnalysisResult() @ 0x0000000032b8dc73 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:339: DB::InterpreterSelectQuery::~InterpreterSelectQuery() @ 0x0000000032b2b966 10. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:90: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000032a97912 11. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97ef6 12. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 13. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 14. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000032a8314d 15. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000032a7c4c4 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:48.267599 [ 18096 ] {f8cc95f1-9527-4e2e-baaf-44dd050a71e0} executeQuery: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 88, line 461) (in query: -- leadInFrame UBsan SELECT leadInFrame(1, -1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd46856 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd46c4d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:18:48.286363 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -1 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd46856 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd46c4d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:18:48.576510 [ 18096 ] {d72aedd9-9c83-4383-a22e-91c023773e67} executeQuery: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 90, line 464) (in query: SELECT leadInFrame(1, /* INT64_MAX+1 */ 0x7fffffffffffffff+1) OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd46856 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd46c4d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:18:48.608586 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: The offset for function leadInFrame must be in (0, 9223372036854775807], -9223372036854775808 given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, long&&, long&) @ 0x000000003bd39357 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2383: DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd46856 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: non-virtual thunk to DB::WindowFunctionLagLeadInFrame::windowInsertResultInto(DB::WindowTransform const*, unsigned long) const @ 0x000000003bd46c4d 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1051: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003bd06d5c 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:1462: DB::WindowTransform::work() @ 0x000000003bd0f73f 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:18:50.563953 [ 18096 ] {6df30b7a-fb35-4930-a4e5-d02e73bdb620} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 93, line 468) (in query: -- nth_value Msan SELECT nth_value(1, '') OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2435: DB::WindowFunctionNthValue::WindowFunctionNthValue(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd37e20 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd37035 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bd12e37 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3287: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046a988 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:18:50.569975 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2435: DB::WindowFunctionNthValue::WindowFunctionNthValue(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd37e20 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd37035 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bd12e37 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3287: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046a988 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:18:50.837957 [ 16703 ] {dc385ef7-e7a7-45af-beda-fad2982bc9b3} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams, 0>(std::allocator const&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&&) @ 0x0000000031c23f3a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031bd1327 9. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031bc9e1b 10. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031bf83ab 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1178: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032b559da 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032b345ca 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b1f0d5 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:486: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b104ae 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:303: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b0fd18 16. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000032a9749d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97ef6 18. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 19. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 20. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000032a8314d 21. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000032a7c4c4 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:18:50.862600 [ 16703 ] {dc385ef7-e7a7-45af-beda-fad2982bc9b3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While processing SELECT a, b, t2_00826.a, t2_00826.b FROM t1_00826 ALL INNER JOIN t2_00826 ON b = t2_00826.a WHERE (b = t2_00826.a) AND ((t2_00826.b IS NULL) OR (t2_00826.b > t2_00826.a)) ORDER BY ALL ASC. (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38974) (comment: 00826_cross_to_inner_join.sql) (query 63, line 80) (in query: EXPLAIN SYNTAX select * from t1_00826 cross join t2_00826 where t1_00826.b = t2_00826.a AND (t2_00826.b IS NULL OR t2_00826.b > t2_00826.a) order by all;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams, 0>(std::allocator const&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&&) @ 0x0000000031c23f3a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031bd1327 9. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031bc9e1b 10. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031bf83ab 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1178: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032b559da 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032b345ca 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b1f0d5 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:486: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b104ae 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:303: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b0fd18 16. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000032a9749d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97ef6 18. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 19. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 20. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000032a8314d 21. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000032a7c4c4 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:18:50.876629 [ 16703 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While processing SELECT a, b, t2_00826.a, t2_00826.b FROM t1_00826 ALL INNER JOIN t2_00826 ON b = t2_00826.a WHERE (b = t2_00826.a) AND ((t2_00826.b IS NULL) OR (t2_00826.b > t2_00826.a)) ORDER BY ALL ASC. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams, 0>(std::allocator const&, std::shared_ptr&, DB::SettingFieldMaxThreads const&, DB::Block const&, DB::StatsCollectingParams&&) @ 0x0000000031c23f3a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::SelectQueryExpressionAnalyzer::makeJoin(DB::ASTTablesInSelectQueryElement const&, std::vector> const&, std::optional&) @ 0x0000000031bd1327 9. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:976: DB::SelectQueryExpressionAnalyzer::appendJoin(DB::ExpressionActionsChain&, std::shared_ptr&) @ 0x0000000031bc9e1b 10. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:2067: DB::ExpressionAnalysisResult::ExpressionAnalysisResult(DB::SelectQueryExpressionAnalyzer&, std::shared_ptr const&, bool, bool, bool, std::shared_ptr const&, std::shared_ptr const&, DB::Block const&) @ 0x0000000031bf83ab 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:1178: DB::InterpreterSelectQuery::getSampleBlockImpl() @ 0x0000000032b559da 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:920: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr)::$_0::operator()(bool) const @ 0x0000000032b345ca 13. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:930: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b1f0d5 14. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:486: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b104ae 15. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:303: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b0fd18 16. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000032a9749d 17. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97ef6 18. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 19. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 20. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000032a8314d 21. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000032a7c4c4 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:18:50.953001 [ 15982 ] {66e2d807-4d0c-4e9b-829e-b5df1a61c096} executeQuery: Code: 36. DB::Exception: Cannot load time zone not a timezone: In scope SELECT makeDateTime(1984, 1, 1, 0, 0, 0, 'not a timezone'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39092) (comment: 02244_make_datetime.sql) (query 20, line 23) (in query: select makeDateTime(1984, 1, 1, 0, 0, 0, 'not a timezone');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001f694584 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000001f6883f6 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f31313a 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f312983 8. std::shared_ptr std::allocate_shared[abi:ne190107], String&, 0>(std::allocator const&, String&) @ 0x000000000d0bb606 9. DB::(anonymous namespace)::FunctionMakeDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475b9e9 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:18:50.958922 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone not a timezone: In scope SELECT makeDateTime(1984, 1, 1, 0, 0, 0, 'not a timezone'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001f694584 5. ./build_docker/./src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000001f6883f6 6. ./src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000002f31313a 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:11: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000002f312983 8. std::shared_ptr std::allocate_shared[abi:ne190107], String&, 0>(std::allocator const&, String&) @ 0x000000000d0bb606 9. DB::(anonymous namespace)::FunctionMakeDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001475b9e9 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:18:52.223208 [ 18096 ] {782fd663-410a-4676-b5b0-58692ac34ca7} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 94, line 471) (in query: -- lagInFrame Msan SELECT lagInFrame(1, '') OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2289: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd3c33c 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd3a3d5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bd12f37 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3287: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046a988 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:18:52.228742 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2289: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd3c33c 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd3a3d5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bd12f37 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3287: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046a988 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:18:53.553558 [ 18096 ] {d19c13d7-ccd1-43fe-bc4a-b4dd7489edf8} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 95, line 474) (in query: -- leadInFrame Msan SELECT leadInFrame(1, '') OVER ();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2289: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd42a9c 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd40b35 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bd13037 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3287: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046a988 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:18:53.560094 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'String' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:2289: DB::WindowFunctionLagLeadInFrame::WindowFunctionLagLeadInFrame(String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd42a9c 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:ne190107], std::allocator>, String const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, String const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000003bd40b35 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000003bd13037 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3287: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046a988 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:18:55.197591 [ 18096 ] {fe83ebc8-0eff-4774-aaea-7d5bff8b5932} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 98, line 490) (in query: -- negative offsets should not be allowed select count() over (order by toInt64(number) range between -1 preceding and unbounded following) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033746e17 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x00000000337461b0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2566: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049faba 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:18:55.209158 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033746e17 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x00000000337461b0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2566: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049faba 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:18:55.262424 [ 18096 ] {f6df9d7c-a4ab-4b2e-97cc-55f4513f7889} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 99, line 492) (in query: select count() over (order by toInt64(number) range between -1 following and unbounded following) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033746e17 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x00000000337461b0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2566: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049faba 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:18:55.270977 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033746e17 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x00000000337461b0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2566: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049faba 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:18:56.295651 [ 18096 ] {ccebbc97-92c8-4838-9ee3-926a2edb857c} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 100, line 493) (in query: select count() over (order by toInt64(number) range between unbounded preceding and -1 preceding) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033746e17 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033746417 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2566: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049faba 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:18:56.302252 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033746e17 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033746417 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2566: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049faba 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:18:56.309051 [ 6078 ] {517b1f21-69f9-4710-9220-b33c92d3dff3} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56866) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: CREATE TABLE src (`A` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/{database}/test/src1', '1') ORDER BY tuple() SETTINGS min_bytes_for_wide_part = 0, index_granularity = 30250, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 63387513, compact_parts_max_granules_to_buffer = 147, compact_parts_merge_max_bytes_to_prefetch_part = 10203847, merge_max_block_size = 407, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 6692194, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 15992913, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 28, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 9163, primary_key_compress_block_size = 82767, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:18:56.363781 [ 6078 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:18:56.387253 [ 18096 ] {cead76d4-8f79-4b79-a661-5e96c0d449ea} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 101, line 494) (in query: select count() over (order by toInt64(number) range between unbounded preceding and -1 following) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033746e17 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033746417 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2566: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049faba 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:18:56.416957 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '-1' of type 'Int64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033746e17 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000033746417 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2566: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049faba 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:18:57.177204 [ 6078 ] {187d2397-3444-41f9-b11f-446fde00f39c} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56898) (comment: 00029_test_zookeeper_optimize_exception.sh) (query 1, line 1) (in query: CREATE TABLE test_optimize_exception_replicated (`date` Date) ENGINE = ReplicatedMergeTree('/clickhouse/tables/00029_test_zookeeper_optimize_exception_test_kpow5649/optimize', 'r1') PARTITION BY toYYYYMM(date) ORDER BY date SETTINGS index_granularity = 50527, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 333292164, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 8652487, merge_max_block_size = 282, old_parts_lifetime = 95., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2954640605, index_granularity_bytes = 28938161, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 46, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 80433, primary_key_compress_block_size = 8006, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:18:57.187742 [ 6078 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:18:57.338610 [ 16223 ] {d1ef31ce-1364-4926-abe7-8e2a4d61ddb0} executeQuery: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56902) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: insert into src values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:18:57.346352 [ 16223 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:18:58.310075 [ 16889 ] {8b7550ad-00a6-4233-a16b-c9f41a9ebcca} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56950) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:18:58.322724 [ 16889 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:18:59.377147 [ 16223 ] {e59e1f5c-f418-412a-9ca2-64268636cc66} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57000) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:18:59.394291 [ 16223 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:00.040101 [ 17383 ] {0b81d617-df49-4248-9585-3d4718321098} executeQuery: Code: 60. DB::Exception: Table test_kpow5649.test_optimize_exception_replicated does not exist. Maybe you meant test_kpow5649.test_optimize_exception?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57036) (comment: 00029_test_zookeeper_optimize_exception.sh) (query 1, line 1) (in query: INSERT INTO test_optimize_exception_replicated VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:00.049495 [ 17383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_kpow5649.test_optimize_exception_replicated does not exist. Maybe you meant test_kpow5649.test_optimize_exception?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:00.804724 [ 18096 ] {7df6eff0-5799-4e89-b260-e5cc22a1ecc7} executeQuery: Code: 36. DB::Exception: Frame start offset for 'ROWS' frame must be a nonnegative 32-bit integer, '2147483648' of type 'UInt64' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 104, line 524) (in query: -- -INT_MIN row offset that can lead to problems with negation, found when fuzzing -- under UBSan. Should be limited to at most INT_MAX. select count() over (rows between 2147483648 preceding and 2147493648 following) from numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033746e17 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x00000000337461b0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2566: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049faba 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:19:00.811002 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'ROWS' frame must be a nonnegative 32-bit integer, '2147483648' of type 'UInt64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000033746e17 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x00000000337461b0 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2566: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049faba 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:19:00.913107 [ 17268 ] {22530875-6ffa-43c8-b8d0-f0b5db8e110e} executeQuery: Code: 60. DB::Exception: Table test_kpow5649.test_optimize_exception_replicated does not exist. Maybe you meant test_kpow5649.test_optimize_exception?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45626) (comment: 00029_test_zookeeper_optimize_exception.sh) (query 1, line 1) (in query: INSERT INTO test_optimize_exception_replicated VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:00.922098 [ 17268 ] {} TCPHandler: Code: 60. DB::Exception: Table test_kpow5649.test_optimize_exception_replicated does not exist. Maybe you meant test_kpow5649.test_optimize_exception?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:01.503877 [ 17383 ] {7d1a203b-fb89-4d77-a0b0-b815782f5e7d} executeQuery: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57062) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 1 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:01.513891 [ 17383 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:02.424293 [ 16215 ] {beec452c-3d9e-4b3c-9848-986ce6290143} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 1) FROM src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45700) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 1) from src format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:02.437190 [ 16215 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 1) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:02.980101 [ 18096 ] {3ef86c0c-bc96-4976-bb8d-8bc6267273fb} executeQuery: Code: 36. DB::Exception: Derived window definition 'w PARTITION BY number' is not allowed to override PARTITION BY. In scope SELECT count() OVER (w PARTITION BY number) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5)). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 108, line 542) (in query: -- can't redefine PARTITION BY select count() over (w partition by number) from numbers(1) window w as (partition by intDiv(number, 5));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:776: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003043b881 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2507: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049e3d9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:19:03.008446 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Derived window definition 'w PARTITION BY number' is not allowed to override PARTITION BY. In scope SELECT count() OVER (w PARTITION BY number) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5)). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:776: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003043b881 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2507: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049e3d9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:19:03.373073 [ 16233 ] {a1c83aff-26f2-4a86-bca0-1f098e92f1fb} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45804) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:03.382153 [ 16233 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:03.401121 [ 18131 ] {951b5c1b-54f4-4d20-9a83-7f1e78dbd29a} executeQuery: Code: 60. DB::Exception: Table test_kpow5649.test_optimize_exception_replicated does not exist. Maybe you meant test_kpow5649.test_optimize_exception?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45738) (comment: 00029_test_zookeeper_optimize_exception.sh) (query 1, line 1) (in query: OPTIMIZE TABLE test_optimize_exception_replicated PARTITION 201709 FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000339558ca 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:19:03.411044 [ 18131 ] {} TCPHandler: Code: 60. DB::Exception: Table test_kpow5649.test_optimize_exception_replicated does not exist. Maybe you meant test_kpow5649.test_optimize_exception?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000339558ca 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:19:04.020266 [ 16215 ] {10a72f97-baba-4733-b808-554a37a0e3e8} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45752) (comment: 02918_analyzer_to_ast_crash.sql) (query 1, line 1) (in query: WITH x AS (SELECT in((SELECT * FROM y))), y AS (SELECT 1) SELECT * FROM x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2978: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003047a7e4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5354: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7c72 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:19:04.027954 [ 16215 ] {} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2978: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003047a7e4 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5354: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7c72 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:19:04.187462 [ 6072 ] {49d8f72f-ef28-4be9-bb71-5281aab4b46e} executeQuery: Code: 388. DB::Exception: Cannot OPTIMIZE table: There are no parts inside partition. (CANNOT_ASSIGN_OPTIMIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45838) (comment: 00029_test_zookeeper_optimize_exception.sh) (query 1, line 1) (in query: OPTIMIZE TABLE test_optimize_exception PARTITION 201710), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1725: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e9ce9 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033957419 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:04.195417 [ 6072 ] {} TCPHandler: Code: 388. DB::Exception: Cannot OPTIMIZE table: There are no parts inside partition. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1725: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e9ce9 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033957419 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:04.308034 [ 18131 ] {19d506a7-b98c-4b6d-947f-a36c6361739f} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45846) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:04.315778 [ 18131 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:04.543861 [ 18096 ] {41a9f682-0f22-4a0a-9092-67c3838ea390} executeQuery: Code: 36. DB::Exception: Derived window definition 'w ORDER BY number ASC' is not allowed to override a non-empty ORDER BY. In scope SELECT count() OVER (w ORDER BY number ASC) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 109, line 545) (in query: -- can't redefine existing ORDER BY select count() over (w order by number) from numbers(1) window w as (partition by intDiv(number, 5) order by mod(number, 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:784: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003043be02 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2507: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049e3d9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:19:04.550435 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Derived window definition 'w ORDER BY number ASC' is not allowed to override a non-empty ORDER BY. In scope SELECT count() OVER (w ORDER BY number ASC) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:784: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003043be02 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2507: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049e3d9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:19:05.013297 [ 16354 ] {3229782b-5eeb-4992-8dc9-e610a2487783} executeQuery: Code: 60. DB::Exception: Table test_kpow5649.test_optimize_exception_replicated does not exist. Maybe you meant test_kpow5649.test_optimize_exception?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45896) (comment: 00029_test_zookeeper_optimize_exception.sh) (query 1, line 1) (in query: OPTIMIZE TABLE test_optimize_exception_replicated PARTITION 201710), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000339558ca 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:19:05.021456 [ 16354 ] {} TCPHandler: Code: 60. DB::Exception: Table test_kpow5649.test_optimize_exception_replicated does not exist. Maybe you meant test_kpow5649.test_optimize_exception?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x00000000339558ca 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:19:05.248922 [ 16354 ] {661c8b65-e21a-49ea-a005-f86a7dd75deb} executeQuery: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45904) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 2 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:05.256176 [ 16354 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:05.989089 [ 18096 ] {bd7091cb-ea32-4cd1-8c13-7e9cc956bde0} executeQuery: Code: 36. DB::Exception: Parent window 'w' is not allowed to define a frame: while processing derived window definition 'w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW'. In scope SELECT count() OVER (w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34470) (comment: 01591_window_functions.sql) (query 110, line 548) (in query: -- parent window can't have frame select count() over (w range unbounded preceding) from numbers(1) window w as (partition by intDiv(number, 5) order by mod(number, 3) rows unbounded preceding);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000278ac8d7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003043bad2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2507: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049e3d9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:19:05.997177 [ 18096 ] {} TCPHandler: Code: 36. DB::Exception: Parent window 'w' is not allowed to define a frame: while processing derived window definition 'w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW'. In scope SELECT count() OVER (w RANGE BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW) FROM numbers(1) WINDOW w AS (PARTITION BY intDiv(number, 5) ORDER BY mod(number, 3) ASC ROWS BETWEEN UNBOUNDED PRECEDING AND CURRENT ROW). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String&&) @ 0x00000000278ac8d7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:792: DB::QueryAnalyzer::mergeWindowWithParentWindow(std::shared_ptr const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003043bad2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2507: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003049e3d9 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3292: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003046aac1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:19:06.192265 [ 20277 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003a3dfd6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003d179be4 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1795: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003d15fa02 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:928: Coordination::ZooKeeper::receiveEvent() @ 0x000000003d15c45b 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:875: Coordination::ZooKeeper::receiveThread() @ 0x000000003d15aaf9 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003d175e4f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:06.195340 [ 3388 ] {} test_15.partitioned_table (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:19:06.197496 [ 16354 ] {9aaf79f4-5029-4fad-8a07-801abab796f1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 2) FROM src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45926) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 2) from src format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:06.198925 [ 3576 ] {} test_7.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:19:06.199955 [ 3226 ] {} test_1.t_mutations_nondeterministic (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:19:06.199234 [ 3269 ] {} test_15.data_rep_02228 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:19:06.200539 [ 3295 ] {} test_7.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:19:06.200224 [ 3275 ] {} test_15.table_3 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:19:06.201030 [ 3214 ] {} test_9.test_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:19:06.207569 [ 16354 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 2) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:06.415782 [ 16199 ] {8bbe01d2-ec01-4303-8074-b1fbd80fba22} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 100.36 MiB (attempt to allocate chunk of 1.53 MiB bytes), maximum: 100.00 MiB.: while pushing to view test_1hzza0oj.mv_01278_1 (9b451c5e-a65c-4a65-98b2-629c33d65db0). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57014) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (query 1, line 2) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x000000003813c894 10. ./build_docker/./src/Columns/ColumnString.cpp:186: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x00000000376e12da 11. ./build_docker/./src/Columns/ColumnNullable.cpp:334: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x00000000375f1f3a 12. ./build_docker/./src/Columns/FilterDescription.cpp:105: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x000000003817c9ad 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:280: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003bb1e107 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:140: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003bb1b304 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003bd8f50b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0eb49 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0dabf 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 29. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:19:06.504196 [ 17385 ] {11e01f22-e14e-4888-af6b-8487c649402b} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45930) (comment: 01021_only_tuple_columns.sql) (query 1, line 2) (in query: CREATE TABLE test (`x` Tuple(UInt64, UInt64)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 16409, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9048921465873718, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 463858005, compact_parts_max_bytes_to_buffer = 173804646, compact_parts_max_granules_to_buffer = 238, compact_parts_merge_max_bytes_to_prefetch_part = 23528436, merge_max_block_size = 24252, old_parts_lifetime = 87., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 8952012597, index_granularity_bytes = 7456402, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 94, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 60159, primary_key_compress_block_size = 70927, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:19:06.512289 [ 17385 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:19:06.516950 [ 16354 ] {366f4b11-3b58-47be-9fbe-38e45ee1df10} executeQuery: Code: 60. DB::Exception: Table test_kpow5649.test_optimize_exception_replicated does not exist. Maybe you meant test_kpow5649.test_optimize_exception?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45946) (comment: 00029_test_zookeeper_optimize_exception.sh) (query 1, line 1) (in query: DROP TABLE test_optimize_exception_replicated), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:06.528286 [ 16354 ] {} TCPHandler: Code: 60. DB::Exception: Table test_kpow5649.test_optimize_exception_replicated does not exist. Maybe you meant test_kpow5649.test_optimize_exception?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:06.573103 [ 3134 ] {} test_7.rmt2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02446/test_7/rmt/replicas/2/is_lost. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000f1265ec 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:697: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003d0083bc 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:665: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x000000003d007980 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:300: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a239816 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a234405 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a230a02 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a25a2bf 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:06.724976 [ 16199 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 100.36 MiB (attempt to allocate chunk of 1.53 MiB bytes), maximum: 100.00 MiB.: while pushing to view test_1hzza0oj.mv_01278_1 (9b451c5e-a65c-4a65-98b2-629c33d65db0). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x000000003813c894 10. ./build_docker/./src/Columns/ColumnString.cpp:186: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x00000000376e12da 11. ./build_docker/./src/Columns/ColumnNullable.cpp:334: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x00000000375f1f3a 12. ./build_docker/./src/Columns/FilterDescription.cpp:105: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x000000003817c9ad 13. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:280: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003bb1e107 14. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:140: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003bb1b304 15. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 16. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 21. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:845: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003bd8f50b 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0eb49 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:165: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0dabf 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 29. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:19:07.088298 [ 17385 ] {0b95d795-6efd-4dcc-9436-e65936721ae0} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45970) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:07.098490 [ 17385 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:07.101446 [ 18149 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:07.729599 [ 17385 ] {7df0192e-0e3e-4d1d-9af2-2161211bc9be} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45986) (comment: 03311_constantnode.sql) (query 1, line 1) (in query: SELECT uniqUpTo(5)(CAST(unhex('00'), 'AggregateFunction(uniqUpTo(5), Nullable(Nothing))'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:19:07.738863 [ 17385 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:19:08.116470 [ 3941 ] {} DDLWorker(test_1_db): Replica seems to be lost: our_log_ptr=116, max_log_ptr=116, local_digest=16097883769261139625, zk_digest=7075074107430096007 2025.11.13 09:19:08.116762 [ 3941 ] {} DatabaseReplicated (test_1_db): Will recover replica with staled log pointer 116 from log pointer 116 2025.11.13 09:19:08.169669 [ 16354 ] {01805a14-aef7-40ea-b6bf-786069384eb9} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46002) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:08.182169 [ 16354 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:09.241984 [ 19619 ] {1f5fd64d-c380-4a4c-813c-dc6064c36d78} executeQuery: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46022) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 3 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:09.250899 [ 19619 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:09.917197 [ 16605 ] {} HTTPServerRequest: Got an HTTP request with no content length and no chunked/multipart encoding, it may be impossible to distinguish graceful EOF from abnormal connection loss 2025.11.13 09:19:10.285806 [ 17385 ] {3d838dfc-00ca-4ae6-8da6-d4c5fbad93d4} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 3) FROM src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46034) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 3) from src format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:10.295194 [ 17385 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 3) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:11.090379 [ 19171 ] {6426cc39-a59e-4511-ab6f-9c9a86d88043} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 209124.235111 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47842) (comment: 01037_polygon_dicts_correctness_fast.sh) (query 3, line 15) (in query: select 'dictGet', 'dict_array' as dict_name, tuple(x, y) as key, dictGet(dict_name, 'value', key) from points order by x, y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x0000000031b8674d 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f732ea 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:19:11.109826 [ 19171 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 209124.235111 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x0000000031b8674d 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f732ea 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:19:11.280809 [ 19619 ] {d7e05f60-c5a1-47b4-b8fa-efad2e081fb0} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41420) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:11.291309 [ 19619 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:11.506446 [ 17385 ] {7ea9971b-7db1-45df-a1b3-97c9e98ae5da} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41428) (comment: 02699_polygons_sym_difference_total.sql) (query 1, line 1) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:11.515689 [ 17385 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:12.267919 [ 16352 ] {2afa69f0-1e04-4f88-9fbf-816a343648ee} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41482) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:12.276439 [ 16352 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:13.243484 [ 19620 ] {06254580-859e-47a6-aa59-2752d9924218} executeQuery: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41518) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 4 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:13.251674 [ 19620 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:14.391049 [ 18392 ] {105ab5fa-ea2b-422d-a6f5-91e91cf29d28} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 4) FROM src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41534) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 4) from src format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:14.401808 [ 18392 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 4) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:15.324751 [ 16231 ] {aaabb147-78ca-4f6f-98fe-9312a8457574} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41554) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:15.336020 [ 16231 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:15.833661 [ 16231 ] {3f033069-db4d-40d1-b552-689827b02856} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41570) (comment: 01854_HTTP_dict_decompression.sh) (query 1, line 1) (in query: DROP DICTIONARY test_table_select), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:19:15.844315 [ 16231 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:19:16.283731 [ 19620 ] {7e1679d1-005f-4abe-8c88-43f6808bafd7} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41586) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:16.292798 [ 19620 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:16.781058 [ 18106 ] {4244c55e-968b-43ce-8823-6813d16d7533} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 100.98 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 100.00 MiB.: while converting source column `reinterpretAsString(number)` to destination column s5: while executing 'FUNCTION _CAST(reinterpretAsString(number) :: 5, Nullable(String) :: 13) -> _CAST(reinterpretAsString(number), Nullable(String)) Nullable(String) : 12'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45982) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (query 1, line 2) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long, char8_t) @ 0x0000000037acba53 10. ./src/Common/COW.h:293: DB::makeNullable(COW::immutable_ptr const&) @ 0x000000003760159c 11. DB::wrapInNullable(COW::immutable_ptr const&, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000002c18e2b7 12. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c92ffd1 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c92f944 14. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 20. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:19:17.025848 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_82_1}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001f85446d 4. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000001f84c969 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:146: CurrentMemoryTracker::injectFault() @ 0x000000001f62af1f 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:269: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000001f8efcd5 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a57ca6b 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a57949e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:17.212788 [ 18700 ] {8d36ddd4-d0fc-4c1d-aef1-aab57d860c3a} executeQuery: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41620) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 5 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:17.227623 [ 18700 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:17.239117 [ 16047 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:18.191707 [ 19618 ] {3d954114-1977-46f2-84f5-25e739b94f5a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 5) FROM src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41632) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 5) from src format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:18.207901 [ 19618 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 5) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:18.321111 [ 18106 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 100.98 MiB (attempt to allocate chunk of 1.02 MiB bytes), maximum: 100.00 MiB.: while converting source column `reinterpretAsString(number)` to destination column s5: while executing 'FUNCTION _CAST(reinterpretAsString(number) :: 5, Nullable(String) :: 13) -> _CAST(reinterpretAsString(number), Nullable(String)) Nullable(String) : 12'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long, char8_t) @ 0x0000000037acba53 10. ./src/Common/COW.h:293: DB::makeNullable(COW::immutable_ptr const&) @ 0x000000003760159c 11. DB::wrapInNullable(COW::immutable_ptr const&, std::vector> const&, std::shared_ptr const&, unsigned long) @ 0x000000002c18e2b7 12. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)::operator()(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) const @ 0x000000002c92ffd1 13. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107] const&, std::shared_ptr const&, bool) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c92f944 14. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 20. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:19:19.142213 [ 17228 ] {4c7055d6-4ebf-46b4-9b67-db65ad49f98b} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41670) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:19.168026 [ 17228 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:20.151038 [ 16446 ] {076eaf47-5a58-450b-a622-4d16c438b6b1} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41712) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:20.170480 [ 16446 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:21.285219 [ 18391 ] {0ca00df2-5edc-4399-a2e0-7aa9db0b1359} executeQuery: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38028) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 6 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:21.301384 [ 18391 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:21.757849 [ 5803 ] {a1217478-9721-4615-bc02-a489bdfc76e7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41700) (comment: 01649_with_alias_key_condition.sql) (query 5, line 9) (in query: with i as k select * from alias_key_condition where k = (select i from alias_key_condition where i = 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:277: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b5e2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:76: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3f962b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c3564d3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 18. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:19:22.246026 [ 17226 ] {0ee139d5-2072-436f-81db-cff13513a761} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 6) FROM src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38044) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 6) from src format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:22.262919 [ 17226 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 6) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:22.377824 [ 16355 ] {6358ac42-81be-42e0-b5bc-7a4d7d1624ee} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort(toFixedString('01/12/2017,', 11)). (CANNOT_PARSE_DATETIME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38004) (comment: 03014_msan_parse_date_time.sql) (query 1, line 1) (in query: SELECT parseDateTimeBestEffort(toFixedString('01/12/2017,', 11));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa051f0 5. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d2a56 6. ./src/Functions/FunctionsConversion.h:2682: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abee4 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:19:22.384200 [ 16355 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort(toFixedString('01/12/2017,', 11)). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa051f0 5. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d2a56 6. ./src/Functions/FunctionsConversion.h:2682: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abee4 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:19:23.146260 [ 16054 ] {e9889a7c-2059-4b55-b51d-1ce9c5396439} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38090) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:23.155696 [ 16054 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:23.919675 [ 5803 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:277: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003c34b5e2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:76: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3f962b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c3564d3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 18. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:632: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003042bb2a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3876: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030417e3b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5659: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc365 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:19:24.236677 [ 16054 ] {576bc6e9-6865-4740-abe5-a01f67015328} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38120) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:24.249781 [ 16054 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:25.310044 [ 16230 ] {c3b02d8a-5388-4278-9407-64515e5c810f} executeQuery: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38138) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 7 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:25.338861 [ 16230 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:26.332217 [ 16230 ] {9f33118f-9847-4d28-8f3d-76add8d5998b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 7) FROM src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38166) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 7) from src format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:26.348547 [ 16230 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 7) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:27.382425 [ 16230 ] {29f2d647-8f63-402f-9a92-3060c443bc32} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38180) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src detach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:27.397180 [ 16230 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:28.376226 [ 16691 ] {81dccdf9-84fc-46c6-bd50-fb07744c0b55} executeQuery: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38220) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src attach partition tuple()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:28.439048 [ 16691 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:19:29.339041 [ 5803 ] {bedb74b9-2f50-4d00-bfc0-c6851878f31d} executeQuery: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38234) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: alter table src update A = 8 where 1 settings mutations_sync=2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:29.355968 [ 5803 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.src does not exist. Maybe you meant test_13.src?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:30.335728 [ 5803 ] {7937224f-9dd7-427b-8c38-01a391fc1eb8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 8) FROM src. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38272) (comment: 02470_mutation_sync_race.sh) (query 1, line 1) (in query: select throwIf(A != 8) from src format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:30.350053 [ 5803 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'src' in scope SELECT throwIf(A != 8) FROM src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:19:31.695640 [ 3727 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_1_98_14} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.06 GiB (attempt to allocate chunk of 1.79 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (avg_value_size_hint = 110.3148193359375, avg_chars_size = 122.777783203125, limit = 8192): (while reading column data): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_1_69_13/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:31.697528 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_1_98_14}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.06 GiB (attempt to allocate chunk of 1.79 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (avg_value_size_hint = 110.3148193359375, avg_chars_size = 122.777783203125, limit = 8192): (while reading column data): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_1_69_13/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:32.368903 [ 16691 ] {c3fe9e8e-6c20-4f9e-ac6f-9c7ec9ed8075} executeQuery: Code: 252. DB::Exception: Too many inactive parts (2) in table 'test_15.data_01709 (cdc9a865-203b-4bca-84e2-c09f70075824)'. Parts cleaning are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38246) (comment: 01709_inactive_parts_to_throw_insert.sql) (query 6, line 10) (in query: insert into data_01709 values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4967: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e9fa 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003a56f7fb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000003b217963 13. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed0f77 14. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:19:32.383229 [ 16691 ] {} TCPHandler: Code: 252. DB::Exception: Too many inactive parts (2) in table 'test_15.data_01709 (cdc9a865-203b-4bca-84e2-c09f70075824)'. Parts cleaning are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4967: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e9fa 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003a56f7fb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x000000003b217963 13. ./build_docker/./src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed0f77 14. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:19:32.568696 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_87_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.07 GiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:32.571031 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_87_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.07 GiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:34.280527 [ 16200 ] {a8c9dda3-5612-4360-b20d-c4c7b1fdfcee} executeQuery: Code: 53. DB::Exception: Function dictGetString dictionary attribute has different type Nullable(String) expected String: In scope SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0)). (TYPE_MISMATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38238) (comment: 02125_dict_get_type_nullable_fix.sql) (query 7, line 22) (in query: SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000916cc6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:19:34.295172 [ 16200 ] {} TCPHandler: Code: 53. DB::Exception: Function dictGetString dictionary attribute has different type Nullable(String) expected String: In scope SELECT dictGetString('02125_test_dictionary', 'value', toUInt64(0)). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000916cc6b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:19:35.222068 [ 16230 ] {53b47f8e-7930-41ef-992c-6508e37a48e9} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48320) (comment: 03206_is_null_constant_result_old_analyzer_bug.sql) (query 3, line 5) (in query: set allow_experimental_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:35.241673 [ 16230 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:35.645123 [ 3731 ] {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_94_19} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.05 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:35.646771 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_94_19}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.05 GiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:35.657790 [ 18771 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.05 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:35.658817 [ 18771 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.05 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:35.736388 [ 18771 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.03 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:35.737253 [ 18771 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.03 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:35.967088 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_87_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.05 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:35.968691 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_87_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.05 GiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:36.188329 [ 18721 ] {4b43e3d9-a83a-42bd-a76c-9c2b4c35108e} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 1, line 4) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('exact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:36.203927 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:36.718079 [ 3734 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_1_98_14} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.04 GiB (attempt to allocate chunk of 1.18 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_1_69_13/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:36.719934 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_1_98_14}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1.04 GiB (attempt to allocate chunk of 1.18 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_1_69_13/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:37.391219 [ 17376 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:37.929747 [ 18721 ] {f418f3ee-cc9c-4daa-867a-7c06a7f5fa56} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 2, line 5) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('cAsE_INSENSITIVE_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:39: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x000000002711847d 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:37.936581 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:39: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x000000002711847d 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:39.239454 [ 18721 ] {4e172cb3-3d41-4f82-b75f-ad61ba32db3a} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 3, line 6) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('bad_header_name: test\nexact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:39.246881 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:39.338484 [ 18721 ] {8a735be1-61de-44ce-8b5c-fdc6b8620962} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 4, line 7) (in query: SELECT * FROM url('http://localhost:8123/', LineAsString, headers('bad_header_value' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:39.345110 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:40.505214 [ 18722 ] {6edb0555-cc17-409f-bfcb-6f81cf7956b7} executeQuery: Code: 27. DB::Exception: Cannot read input: expected a digit but got something else: In scope SELECT toModifiedJulianDay('unparsable'). (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48422) (comment: 01543_toModifiedJulianDay.sql) (query 6, line 8) (in query: SELECT toModifiedJulianDay('unparsable');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::readDigit(DB::ReadBuffer&) @ 0x000000000aeb0507 5. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000aeafabf 6. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000aeb1561 7. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ab4f263 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:19:40.512901 [ 18722 ] {} TCPHandler: Code: 27. DB::Exception: Cannot read input: expected a digit but got something else: In scope SELECT toModifiedJulianDay('unparsable'). (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::readDigit(DB::ReadBuffer&) @ 0x000000000aeb0507 5. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000aeafabf 6. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000aeb1561 7. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ab4f263 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:19:41.384242 [ 3739 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_101_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1017.62 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f6c4318 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:41.395123 [ 18721 ] {676d4b02-b897-4fba-a17d-45d488c798d9} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 6, line 10) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('exact_header' = 'value'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:59: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x0000000038e9cd61 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x0000000026771038 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026773b6c 8. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:41.406334 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_101_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1017.62 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f6c4318 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:41.408475 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_87_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1017.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:41.411359 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_87_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1017.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:41.411591 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:59: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x0000000038e9cd61 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x0000000026771038 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026773b6c 8. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:42.032526 [ 18722 ] {99e6e05d-2ffd-49e8-8527-91960b8b7638} executeQuery: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 2, day_of_month: 29).: In scope SELECT toModifiedJulianDay('1999-02-29'). (CANNOT_PARSE_DATE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48422) (comment: 01543_toModifiedJulianDay.sql) (query 7, line 9) (in query: SELECT toModifiedJulianDay('1999-02-29');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x000000000aeb3e17 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000aeb0093 5. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000aeb1561 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ab4f263 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:19:42.046116 [ 18722 ] {} TCPHandler: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 2, day_of_month: 29).: In scope SELECT toModifiedJulianDay('1999-02-29'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x000000000aeb3e17 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000aeb0093 5. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000aeb1561 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ab4f263 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:19:42.087973 [ 18722 ] {ecf58243-0038-4227-a582-e4c64d34fe14} executeQuery: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 13, day_of_month: 32).: In scope SELECT toModifiedJulianDay('1999-13-32'). (CANNOT_PARSE_DATE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48422) (comment: 01543_toModifiedJulianDay.sql) (query 8, line 10) (in query: SELECT toModifiedJulianDay('1999-13-32');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x000000000aeb3e17 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000aeb0093 5. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000aeb1561 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ab4f263 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:19:42.187410 [ 18722 ] {} TCPHandler: Code: 38. DB::Exception: Invalid date, out of range (year: 1999, month: 13, day_of_month: 32).: In scope SELECT toModifiedJulianDay('1999-13-32'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x000000000aeb3e17 4. DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000aeb0093 5. DB::GregorianDate::GregorianDate(DB::ReadBuffer&) @ 0x000000000aeb1561 6. DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ab4f263 7. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:19:42.288939 [ 3725 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_69_13} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1001.47 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:42.291390 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_69_13}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 1001.47 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:42.453840 [ 18721 ] {a5291c2d-6281-445c-8900-7befcaa299b2} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 7, line 11) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('cAsE_INSENSITIVE_header' = 'value'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:39: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x000000002711847d 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:59: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x0000000038e9cd61 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x0000000026771038 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026773b6c 8. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:42.461493 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:39: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x000000002711847d 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:59: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x0000000038e9cd61 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x0000000026771038 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026773b6c 8. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:42.519338 [ 3733 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_112_23} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 997.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/42e/42e4c43f-6d1d-497c-bdaf-685199a73f25/202511_1_107_22/data.bin (position: 152801, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: a65a1e2618662e97354bea8dd4f9ec5082c757010015450400): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/42e/42e4c43f-6d1d-497c-bdaf-685199a73f25/202511_1_107_22/ in table system.transactions_info_log (42e4c43f-6d1d-497c-bdaf-685199a73f25) located on disk default of type local, from mark 0 with max_rows_to_read = 8229): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:42.520768 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_112_23}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 997.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/42e/42e4c43f-6d1d-497c-bdaf-685199a73f25/202511_1_107_22/data.bin (position: 152801, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: a65a1e2618662e97354bea8dd4f9ec5082c757010015450400): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/42e/42e4c43f-6d1d-497c-bdaf-685199a73f25/202511_1_107_22/ in table system.transactions_info_log (42e4c43f-6d1d-497c-bdaf-685199a73f25) located on disk default of type local, from mark 0 with max_rows_to_read = 8229): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:42.778200 [ 3736 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 979.56 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:42.779743 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 979.56 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.563005 [ 3916 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TraceLogElement]: Failed to flush system log system.trace_log with 772 entries up to offset 61098: Code: 241. DB::Exception: (total) memory limit exceeded: would use 995.25 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033318461 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.582410 [ 18721 ] {3dc27d22-a14a-4c3e-9e9d-99a487e4eb7b} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 8, line 12) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('bad_header_name: test\nexact_header' = 'value'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:59: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x0000000038e9cd61 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x0000000026771038 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026773b6c 8. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:43.590769 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:59: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x0000000038e9cd61 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x0000000026771038 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026773b6c 8. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:43.604915 [ 18771 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 933.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.605905 [ 18771 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 933.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.608853 [ 3726 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_112_23} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 933.71 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.610414 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_112_23}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 933.71 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.646051 [ 18721 ] {57050eb6-3708-4709-8124-ef73b667ae12} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 9, line 13) (in query: SELECT * FROM urlCluster('test_cluster_two_shards_localhost', 'http://localhost:8123/', LineAsString, headers('bad_header_value' = 'test\nexact_header: value'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:59: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x0000000038e9cd61 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x0000000026771038 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026773b6c 8. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:43.664095 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/StorageURLCluster.cpp:59: DB::StorageURLCluster::StorageURLCluster(std::shared_ptr const&, String const&, String const&, String const&, String const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::StorageURL::Configuration const&) @ 0x0000000038e9cd61 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID, DB::ColumnsDescription, DB::ConstraintsDescription, DB::StorageURL::Configuration const&, 0>(std::allocator const&, std::shared_ptr&, String const&, String const&, String const&, String const&, DB::StorageID&&, DB::ColumnsDescription&&, DB::ConstraintsDescription&&, DB::StorageURL::Configuration const&) @ 0x0000000026771038 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURLCluster::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000026773b6c 8. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:43.664855 [ 3739 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 928.81 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.667166 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 928.81 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.697526 [ 18771 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 924.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.698417 [ 18771 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 924.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.707499 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_88_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 933.77 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:43.709901 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_88_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 933.77 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:45.110225 [ 3733 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 916.68 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:45.111810 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 916.68 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:45.417030 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_88_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 899.12 MiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:45.418895 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_88_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 899.12 MiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:45.867797 [ 3726 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 858.13 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:45.870319 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 858.13 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:46.163790 [ 17390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 918.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::StaticRequestHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ae94078 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:46.224058 [ 19606 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 836.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::StaticRequestHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003ae94078 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:46.368988 [ 19606 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 819.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:47.319227 [ 16198 ] {131e6e6b-35a8-410f-a7a2-2e5f88a5217a} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 69696.878133 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46162) (comment: 03094_grouparraysorted_memory.sql) (query 4, line 36) (in query: INSERT INTO 03094_grouparrysorted_src SELECT * FROM generateRandom() LIMIT 500000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:19:47.323133 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_88_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 828.24 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:47.324697 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_88_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 828.24 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:47.357041 [ 18824 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 814.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:47.358196 [ 18824 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 814.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:47.404711 [ 16198 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 69696.878133 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:19:47.446111 [ 3739 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 820.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:47.448829 [ 16230 ] {02d4b87d-8fd9-4aad-a7ee-d76977092064} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 805.49 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48334) (comment: 02521_aggregation_by_partitions.sql) (query 14, line 23) (in query: -- { echoOff } select count() from (select throwIf(count() != 2) from t1 group by a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:19:47.463090 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 820.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:47.695960 [ 17376 ] {dfc95d2e-79ba-43b4-aa69-16cde5e3c4c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48458) (comment: 01710_projection_fetch_long.sql) (query 10, line 18) (in query: select * from tp_2 order by x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:828: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039c3bc0b 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1866: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c2aea5b 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1084: DB::MergeTreeDataSelectExecutor::estimateNumMarksToRead(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>) const @ 0x0000000039c4db33 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:252: DB::QueryPlanOptimizations::analyzeProjectionCandidate(DB::QueryPlanOptimizations::ProjectionCandidate&, DB::ReadFromMergeTree const&, DB::MergeTreeDataSelectExecutor const&, std::vector> const&, DB::RangesInDataParts const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr, std::equal_to, std::allocator>>> const&, DB::ActionsDAG const*) @ 0x000000003c58c215 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseNormalProjection.cpp:177: DB::QueryPlanOptimizations::optimizeUseNormalProjections(std::vector>&, std::list>&) @ 0x000000003c57fdf8 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:218: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c4be8 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:19:47.720076 [ 17376 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 6. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:828: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x0000000039c3bc0b 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1866: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::optional const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000003c2aea5b 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1084: DB::MergeTreeDataSelectExecutor::estimateNumMarksToRead(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>) const @ 0x0000000039c4db33 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/projectionsCommon.cpp:252: DB::QueryPlanOptimizations::analyzeProjectionCandidate(DB::QueryPlanOptimizations::ProjectionCandidate&, DB::ReadFromMergeTree const&, DB::MergeTreeDataSelectExecutor const&, std::vector> const&, DB::RangesInDataParts const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr, std::equal_to, std::allocator>>> const&, DB::ActionsDAG const*) @ 0x000000003c58c215 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseNormalProjection.cpp:177: DB::QueryPlanOptimizations::optimizeUseNormalProjections(std::vector>&, std::list>&) @ 0x000000003c57fdf8 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:218: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c4be8 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:19:47.788693 [ 16230 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 805.49 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:19:47.974472 [ 16132 ] {4650ea10-bd5c-4c9e-8f8a-41afda11cb21} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38416) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_mdjr5gj0.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:19:48.074555 [ 18824 ] {c68b8679-a210-4d70-be24-562446aa2d4d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46042) (comment: 02521_aggregation_by_partitions.sql) (in query: DROP DATABASE IF EXISTS test_1rm6j1vo SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:19:48.089227 [ 18824 ] {c68b8679-a210-4d70-be24-562446aa2d4d} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:48.248255 [ 16132 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:19:49.094153 [ 18721 ] {10af2464-65d3-4d4d-befe-03c10a903626} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 11, line 16) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('exact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:135: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x000000002d467954 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1a7e 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1341 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026849e53 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:49.103547 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:135: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x000000002d467954 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1a7e 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1341 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026849e53 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:49.646982 [ 16397 ] {7a674f5b-d40e-4a86-abff-ea900344f2c7} executeQuery: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1/1.bin. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38288) (comment: 03030_system_flush_distributed_settings.sql) (query 15, line 20) (in query: system flush distributed dist_in;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:633: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x000000003945aa6a 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003944e74a 11. ./build_docker/./src/Storages/StorageDistributed.cpp:1781: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000384b148e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026d57d8a 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026d579ad 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026d576df 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:50.397031 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_88_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:50.410161 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_88_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:50.575955 [ 3725 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:50.586779 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_102_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:50.773125 [ 16397 ] {} TCPHandler: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1/1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:633: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x000000003945aa6a 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003944e74a 11. ./build_docker/./src/Storages/StorageDistributed.cpp:1781: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000384b148e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026d57d8a 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026d579ad 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026d576df 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1779: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000384a2e36 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1751: DB::StorageDistributed::flushClusterNodesAllData(std::shared_ptr, DB::SettingsChanges const&) @ 0x00000000384a56d4 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1365: DB::InterpreterSystemQuery::flushDistributed(DB::ASTSystemQuery&) @ 0x000000003390e631 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:755: DB::InterpreterSystemQuery::execute() @ 0x00000000338e4fcb 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:50.997421 [ 18721 ] {e4f19c4b-2207-422c-a9e5-73247ac3105f} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 12, line 17) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('cAsE_INSENSITIVE_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:39: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x000000002711847d 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:135: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x000000002d467954 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1a7e 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1341 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026849e53 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:51.010369 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:39: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x000000002711847d 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:135: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x000000002d467954 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1a7e 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1341 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026849e53 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:51.270532 [ 3727 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_169_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.12 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:51.272216 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_169_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.12 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:51.716132 [ 18771 ] {3bfa3112-1a67-4ecc-bbf8-9243639fc362} executeQuery: Code: 70. DB::Exception: Conversion from IntervalDay to Decimal(10, 10) is not supported: In scope SELECT CAST(toIntervalDay(1), 'Nullable(Decimal(10, 10))'). (CANNOT_CONVERT_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33174) (comment: 00879_cast_to_decimal_crash.sql) (query 1, line 1) (in query: select cast(toIntervalDay(1) as Nullable(Decimal(10, 10)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const @ 0x000000002c6af302 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c365343 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c31f2c1 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c31a528 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c319085 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3559: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474b70 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:51.724677 [ 18771 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from IntervalDay to Decimal(10, 10) is not supported: In scope SELECT CAST(toIntervalDay(1), 'Nullable(Decimal(10, 10))'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createDecimalWrapper>>(std::shared_ptr const&, T const*, bool) const @ 0x000000002c6af302 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c365343 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c31f2c1 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c31a528 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c319085 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3559: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474b70 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:53.156058 [ 18721 ] {4a8d5042-78e1-4c62-a904-59f0744fa6d9} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 13, line 18) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('bad_header_name: test\nexact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:135: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x000000002d467954 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1a7e 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1341 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026849e53 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:53.164906 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:135: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x000000002d467954 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1a7e 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1341 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026849e53 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:53.382404 [ 18721 ] {d1193285-8548-4314-97c4-094c5a8bbd31} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 14, line 19) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('bad_header_value' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:135: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x000000002d467954 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1a7e 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1341 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026849e53 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:53.383821 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 923.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:53.385173 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 923.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:53.391094 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:135: DB::StorageObjectStorage::StorageObjectStorage(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::optional, DB::LoadingStrictnessLevel, bool, std::shared_ptr, bool) @ 0x000000002d467954 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:ne190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, DB::StorageObjectStorage*>(DB::StorageObjectStorage*, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1a7e 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool&, std::nullptr_t, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::nullopt_t const&, DB::LoadingStrictnessLevel&&, bool&, std::nullptr_t&&) @ 0x00000000268d1341 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorage::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026849e53 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:19:53.753884 [ 3737 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 923.28 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:53.755806 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 923.28 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:54.166751 [ 18771 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 916.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:54.167764 [ 18771 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 916.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:54.280243 [ 15982 ] {ba0975f4-cd59-4376-b0ca-9e58e9695e86} ConnectionPoolWithFailover: Connection failed at try â„–1, reason: Code: 210. DB::NetException: Net Exception: Connection reset by peer (127.2:9000, 127.0.0.2, local address: 127.0.0.1:39566). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:54.438159 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_89_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 916.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:54.441696 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_89_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 916.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:54.488694 [ 3736 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 884.12 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:54.490522 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 884.12 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:54.819787 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 2264 entries up to offset 192307: Code: 241. DB::Exception: (total) memory limit exceeded: would use 896.40 MiB (attempt to allocate chunk of 4.17 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:55.095931 [ 18721 ] {9e731521-4854-4aa3-9ac2-b08bb36a3a4b} executeQuery: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading 4: While executing S3(_table_function.s3)Source. (S3_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 15, line 20) (in query: SELECT * FROM s3('http://localhost:8123/123/4', LineAsString, headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/IO/S3Common.h:34: DB::S3Exception::S3Exception(Aws::S3::S3Errors, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000002d8ca9ab 4. ./build_docker/./src/IO/S3/getObjectInfo.cpp:105: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool) @ 0x000000002d8c9c13 5. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:363: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x000000002d8aa878 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:867: DB::StorageObjectStorageSource::KeysIterator::next(unsigned long) @ 0x000000002d59f93c 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:403: DB::StorageObjectStorageSource::createReader(unsigned long, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ReadFromFormatInfo&, std::optional const&, std::shared_ptr const&, std::shared_ptr const&, DB::SchemaCache*, std::shared_ptr const&, unsigned long, unsigned long, bool) @ 0x000000002d585309 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:367: DB::StorageObjectStorageSource::lazyInitialize() @ 0x000000002d57fdb6 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:221: DB::StorageObjectStorageSource::generate() @ 0x000000002d580ee7 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:19:55.214449 [ 18721 ] {} TCPHandler: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading 4: While executing S3(_table_function.s3)Source. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/IO/S3Common.h:34: DB::S3Exception::S3Exception(Aws::S3::S3Errors, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000002d8ca9ab 4. ./build_docker/./src/IO/S3/getObjectInfo.cpp:105: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool) @ 0x000000002d8c9c13 5. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:363: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x000000002d8aa878 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:867: DB::StorageObjectStorageSource::KeysIterator::next(unsigned long) @ 0x000000002d59f93c 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:403: DB::StorageObjectStorageSource::createReader(unsigned long, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ReadFromFormatInfo&, std::optional const&, std::shared_ptr const&, std::shared_ptr const&, DB::SchemaCache*, std::shared_ptr const&, unsigned long, unsigned long, bool) @ 0x000000002d585309 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:367: DB::StorageObjectStorageSource::lazyInitialize() @ 0x000000002d57fdb6 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:221: DB::StorageObjectStorageSource::generate() @ 0x000000002d580ee7 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 16. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:19:55.329822 [ 15982 ] {ba0975f4-cd59-4376-b0ca-9e58e9695e86} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 879.40 MiB (attempt to allocate chunk of 1.31 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41646) (comment: 02225_parallel_distributed_insert_select_view.sh) (query 5, line 10) (in query: INSERT INTO FUNCTION remote('127.{1,2}', currentDatabase(), dst_02225, key) SETTINGS parallel_distributed_insert_select = 2, max_distributed_depth = 1 SELECT * FROM remote('127.{1,2}', view(SELECT * FROM test_11.src_02225)) SETTINGS parallel_distributed_insert_select = 2, max_distributed_depth = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9c535 14. ./build_docker/./src/Client/Connection.cpp:1133: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003aaa30f1 15. ./build_docker/./src/Client/MultiplexedConnections.cpp:119: DB::MultiplexedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x000000003ab97fb2 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:928: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002f27ba1e 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:441: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278249 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 19. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 20. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 21. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:19:55.336707 [ 18771 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39572, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:55.337442 [ 18771 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39572, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:55.443762 [ 3734 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 874.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:55.494506 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 874.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:55.499496 [ 15982 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 879.40 MiB (attempt to allocate chunk of 1.31 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9c535 14. ./build_docker/./src/Client/Connection.cpp:1133: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003aaa30f1 15. ./build_docker/./src/Client/MultiplexedConnections.cpp:119: DB::MultiplexedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x000000003ab97fb2 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:928: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002f27ba1e 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:441: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278249 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 19. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 20. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 21. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:19:55.636562 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_169_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 892.99 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:55.638276 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_169_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 892.99 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.201077 [ 3732 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_165_170_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 877.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.203433 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_165_170_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 877.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.255337 [ 3736 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 880.16 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.257070 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 880.16 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.310893 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_89_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 878.09 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.312733 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_89_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 878.09 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.617938 [ 18721 ] {51ef9761-5871-4166-a8bc-0c5c54e5f1f3} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 16, line 22) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('exact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:68: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x000000002d494014 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x0000000026961410 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002695e06a 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:56.622544 [ 15982 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 858.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.623512 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 858.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.627751 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:68: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x000000002d494014 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x0000000026961410 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002695e06a 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:56.697109 [ 3733 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_165_170_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 860.06 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.699506 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_165_170_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 860.06 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.860593 [ 3730 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 861.15 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.862449 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 861.15 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:56.994272 [ 18771 ] {371fc8ef-6a51-45bd-8a05-4d32e99e14a4} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 863.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41732) (comment: 00505_shard_secure.sh) (query 1, line 1) (in query: SELECT * FROM remoteSecure('127.0.0.{1,2}:9440', system.one);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./build_docker/./src/Client/HedgedConnections.cpp:407: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003ab395af 15. ./build_docker/./src/Client/HedgedConnections.cpp:386: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003ab36893 16. ./build_docker/./src/Client/HedgedConnections.cpp:360: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab38dab 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 18. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 19. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 20. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:19:57.043323 [ 18771 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 863.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./build_docker/./src/Client/HedgedConnections.cpp:407: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003ab395af 15. ./build_docker/./src/Client/HedgedConnections.cpp:386: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003ab36893 16. ./build_docker/./src/Client/HedgedConnections.cpp:360: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab38dab 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 18. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 19. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 20. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:19:57.346183 [ 3731 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_69_13} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 878.09 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_68_68_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 43): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:57.348394 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_69_13}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 878.09 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_68_68_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 43): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:57.448065 [ 18824 ] {6d432cf0-f913-43f2-8315-f006016f7382} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 889.62 MiB (attempt to allocate chunk of 16.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41610) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_mdjr5gj0.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./src/Functions/FunctionsConversion.h:1532: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf777d 13. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 14. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 15. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 21. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 22. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 27. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 28. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 29. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:19:57.480900 [ 18824 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 889.62 MiB (attempt to allocate chunk of 16.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./src/Functions/FunctionsConversion.h:1532: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf777d 13. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 14. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 15. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 21. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 22. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 27. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 28. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 29. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:19:57.859534 [ 15982 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 819.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:57.860388 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 819.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:57.917614 [ 18721 ] {3aaf7a7f-fd7c-40b1-93ac-09ef5eaa21ba} executeQuery: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 17, line 23) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('cAsE_INSENSITIVE_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:39: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x000000002711847d 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:68: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x000000002d494014 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x0000000026961410 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002695e06a 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:57.924593 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "cAsE_INSENSITIVE_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:39: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x000000002711847d 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:68: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x000000002d494014 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x0000000026961410 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002695e06a 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:57.980838 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1302 entries up to offset 357233: Code: 241. DB::Exception: (total) memory limit exceeded: would use 814.71 MiB (attempt to allocate chunk of 4.02 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:58.082757 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_89_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 828.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:58.084475 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_89_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 828.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:58.124944 [ 16397 ] {23a5e0b7-08a4-46d1-b586-68d92a79486e} executeQuery: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: (total) memory limit exceeded: would use 889.62 MiB (attempt to allocate chunk of 16.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./src/Functions/FunctionsConversion.h:1532: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf777d 13. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 14. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 15. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 21. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 22. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 27. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 28. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 29. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38288) (comment: 03030_system_flush_distributed_settings.sql) (query 16, line 21) (in query: system flush distributed dist_in settings max_memory_usage=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000039455686 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003944e74a 11. ./build_docker/./src/Storages/StorageDistributed.cpp:1781: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000384b148e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026d57d8a 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026d579ad 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026d576df 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:19:58.127694 [ 6078 ] {a8229900-1b4e-4e50-a616-48a7211a4274} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56960) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_01516_test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:58.137410 [ 6078 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:58.150342 [ 16397 ] {} TCPHandler: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: (total) memory limit exceeded: would use 889.62 MiB (attempt to allocate chunk of 16.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./src/Functions/FunctionsConversion.h:1532: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf777d 13. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 14. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 15. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 21. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 22. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 27. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 28. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 29. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000039455686 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003944e74a 11. ./build_docker/./src/Storages/StorageDistributed.cpp:1781: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000384b148e 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026d57d8a 13. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026d579ad 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026d576df 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1779: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000384a2e36 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1751: DB::StorageDistributed::flushClusterNodesAllData(std::shared_ptr, DB::SettingsChanges const&) @ 0x00000000384a56d4 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1365: DB::InterpreterSystemQuery::flushDistributed(DB::ASTSystemQuery&) @ 0x000000003390e631 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:755: DB::InterpreterSystemQuery::execute() @ 0x00000000338e4fcb 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:19:59.113466 [ 3724 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_165_170_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 850.43 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_169_169_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 888): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:59.115010 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_165_170_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 850.43 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_169_169_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 888): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:59.165361 [ 3735 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 855.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:59.169576 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_103_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 855.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:59.687793 [ 18721 ] {ebafbc56-affd-448f-b701-7a970dd4d0cd} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 18, line 24) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('bad_header_name: test\nexact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:68: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x000000002d494014 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x0000000026961410 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002695e06a 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:59.699721 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_name: test exact_header" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:68: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x000000002d494014 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x0000000026961410 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002695e06a 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:59.783390 [ 3730 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_95_19} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.10 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:59.794318 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_95_19}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.10 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:59.801613 [ 16889 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:59.802515 [ 16889 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:19:59.864877 [ 18721 ] {ce6d1385-4675-4a37-a353-1062a3d374a8} executeQuery: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 19, line 25) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('bad_header_value' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:68: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x000000002d494014 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x0000000026961410 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002695e06a 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:19:59.891241 [ 18721 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "bad_header_value" has invalid character. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:23: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x00000000271185dd 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:97: DB::StorageS3Configuration::check(std::shared_ptr) @ 0x000000002d67718b 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:68: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x000000002d494014 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x0000000026961410 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002695e06a 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 10. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:20:00.041058 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_89_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.09 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:00.043010 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_68_89_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.09 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:00.063319 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_165_170_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 847.13 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:00.065313 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_165_170_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 847.13 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:00.754576 [ 19606 ] {} virtual DB::AutoFinalizedWriteBuffer::~AutoFinalizedWriteBuffer() [Base = DB::WriteBufferFromPocoSocket]: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:8123 -> [::1]:46026). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. DB::WriteBuffer::next() @ 0x0000000008c37ea1 5. ./src/IO/WriteBuffer.h:127: DB::WriteBuffer::finalizeImpl() @ 0x000000001f922529 6. ./build_docker/./src/IO/WriteBuffer.cpp:95: DB::WriteBuffer::finalize() @ 0x000000001f9df056 7. ./src/IO/AutoFinalizedWriteBuffer.h:25: DB::AutoFinalizedWriteBuffer::~AutoFinalizedWriteBuffer() @ 0x000000003af402aa 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:67: std::__shared_ptr_emplace, std::allocator>>::__on_zero_shared() @ 0x000000003af4020d 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:156: DB::HTTPServerResponse::~HTTPServerResponse() @ 0x000000003af360eb 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:91: DB::HTTPServerConnection::run() @ 0x000000003af33304 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:01.031287 [ 18403 ] {38fc2278-37b1-44ec-b828-47bd7f4c3a39} executeQuery: Code: 32. DB::Exception: Attempt to read after eof. (ATTEMPT_TO_READ_AFTER_EOF) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41774) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_mdjr5gj0.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000001f9dd64c 5. ./src/IO/VarInt.h:78: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x000000003aeedcf5 6. ./build_docker/./src/Server/TCPHandler.cpp:933: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed1d75 7. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:01.612168 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_90_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.68 MiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:01.631993 [ 17268 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 868.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:01.632863 [ 17268 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 868.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:01.677004 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_90_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.68 MiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:01.732372 [ 18403 ] {38fc2278-37b1-44ec-b828-47bd7f4c3a39} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 32. DB::Exception: Attempt to read after eof. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000001f9dd64c 5. ./src/IO/VarInt.h:78: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x000000003aeedcf5 6. ./build_docker/./src/Server/TCPHandler.cpp:1032: DB::TCPHandler::skipData(DB::QueryState&) @ 0x000000003aed663f 7. ./build_docker/./src/Server/TCPHandler.cpp:831: DB::TCPHandler::runImpl() @ 0x000000003aea5725 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:01.739851 [ 18403 ] {} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof. (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/VarInt.cpp:13: DB::throwReadAfterEOF() @ 0x000000001f9dd64c 5. ./src/IO/VarInt.h:78: DB::TCPHandler::receivePacketsExpectData(DB::QueryState&) @ 0x000000003aeedcf5 6. ./build_docker/./src/Server/TCPHandler.cpp:933: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed1d75 7. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:01.975112 [ 18771 ] {95f6e9b1-a201-4c48-8598-a5672bceb06b} executeQuery: Code: 36. DB::Exception: StorageExecutable argument "foobar" is invalid query. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48388) (comment: 02517_executable_pool_bad_input_query.sql) (query 1, line 1) (in query: CREATE TABLE test_table (value String) ENGINE=ExecutablePool('nonexist.py', 'TabSeparated', (foobar));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageExecutable.cpp:235: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000384e7b65 5. ./build_docker/./src/Storages/StorageExecutable.cpp:285: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000384e973f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:01.983249 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: StorageExecutable argument "foobar" is invalid query. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageExecutable.cpp:235: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000384e7b65 5. ./build_docker/./src/Storages/StorageExecutable.cpp:285: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000384e973f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:02.026414 [ 18771 ] {edbfff8a-ccad-40d4-95e5-48cd0c939fe3} executeQuery: Code: 36. DB::Exception: StorageExecutable argument "'(SELECT 1)'" is invalid query. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48388) (comment: 02517_executable_pool_bad_input_query.sql) (query 2, line 2) (in query: CREATE TABLE test_table (value String) ENGINE=ExecutablePool('nonexist.py', 'TabSeparated', '(SELECT 1)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageExecutable.cpp:235: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000384e7b65 5. ./build_docker/./src/Storages/StorageExecutable.cpp:285: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000384e973f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:02.040552 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: StorageExecutable argument "'(SELECT 1)'" is invalid query. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageExecutable.cpp:235: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000384e7b65 5. ./build_docker/./src/Storages/StorageExecutable.cpp:285: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000384e973f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:02.092176 [ 3728 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_104_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 875.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:02.106137 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_104_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 875.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:02.108885 [ 16690 ] {480cf187-0f0f-4758-b019-f7776aeb8948} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0): (while reading prefix of column json): (while reading from part /var/lib/clickhouse/store/348/348b0315-b637-461f-97ea-b70806246421/all_1_2_2/ in table test_5.test (348b0315-b637-461f-97ea-b70806246421) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33106) (comment: 03280_json_subcolumns_in_primary_key_select_final.gen.sql) (query 26, line 42) (in query: select * from test final order by value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:376: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::NameAndTypePair const&, unsigned long, unsigned long, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::function)::$_1, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eef7c6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5f53f0 12. ./build_docker/./src/DataTypes/Serializations/SerializationObject.cpp:361: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f71ed91 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:378: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, unsigned long, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::function) @ 0x0000000039eec505 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:397: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>)::$_0::operator()() const @ 0x0000000039eee612 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::unordered_map, std::hash, std::equal_to, std::allocator>>> std::__function::__policy_invoker, std::hash, std::equal_to, std::allocator>>> ()>::__call_impl[abi:ne190107] (DB::NameAndTypePair const&)>)::$_0, std::unordered_map, std::hash, std::equal_to, std::allocator>>> ()>>(std::__function::__policy_storage const*) @ 0x0000000039eef964 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039ef67ce 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:420: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>) @ 0x0000000039eecc0a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:427: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee7933 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c358f91 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 2025.11.13 09:20:02.126497 [ 18771 ] {19633aa1-65d9-4dbb-899b-c8b908a88837} executeQuery: Code: 36. DB::Exception: StorageExecutable argument "[1, 2, 3]" is invalid query. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48388) (comment: 02517_executable_pool_bad_input_query.sql) (query 3, line 3) (in query: CREATE TABLE test_table (value String) ENGINE=ExecutablePool('nonexist.py', 'TabSeparated', [1,2,3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageExecutable.cpp:235: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000384e7b65 5. ./build_docker/./src/Storages/StorageExecutable.cpp:285: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000384e973f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:02.176292 [ 18771 ] {} TCPHandler: Code: 36. DB::Exception: StorageExecutable argument "[1, 2, 3]" is invalid query. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageExecutable.cpp:235: DB::registerStorageExecutable(DB::StorageFactory&)::$_1::operator()(DB::StorageFactory::Arguments const&, bool) const @ 0x00000000384e7b65 5. ./build_docker/./src/Storages/StorageExecutable.cpp:285: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x00000000384e973f 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:02.174246 [ 18786 ] {b9947ae8-6c03-4fec-b707-4585d8b38cb9} StorageDistributed (dist_in): Cannot flush: Code: 241. DB::Exception: (total) memory limit exceeded: would use 850.42 MiB (attempt to allocate chunk of 2.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c00 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:207: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c48b 13. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x000000003dd2bc22 14. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x000000003dd2c20d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6f5827 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003b0c9858 18. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertHelpers.cpp:57: DB::writeAndConvert(DB::RemoteInserter&, DB::DistributedAsyncInsertHeader const&, DB::ReadBufferFromFile&) @ 0x000000003949030f 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::writeRemoteConvert(DB::DistributedAsyncInsertHeader const&, DB::RemoteInserter&, bool, DB::ReadBufferFromFile&, std::shared_ptr) @ 0x0000000039492791 20. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:282: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b0e2 21. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 22. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000039455686 23. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 24. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:173: DB::DistributedAsyncInsertDirectoryQueue::flushAllData(DB::SettingsChanges const&) @ 0x000000003944e74a 25. ./build_docker/./src/Storages/StorageDistributed.cpp:1781: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::SettingsChanges const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000384b148e 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026d57d8a 27. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026d579ad 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026d576df 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 5. ./build_docker/./src/Storages/StorageDistributed.cpp:1779: DB::StorageDistributed::flushClusterNodesAllDataImpl(std::shared_ptr, DB::SettingsChanges const&, bool) @ 0x00000000384a2e36 6. ./build_docker/./src/Storages/StorageDistributed.cpp:1741: DB::StorageDistributed::flushAndPrepareForShutdown() @ 0x00000000384a0916 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:450: void std::__function::__policy_invoker::__call_impl[abi:ne190107]&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000032a795be 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000026d57d8a 9. ./src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x0000000026d579ad 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000026d576df 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a738e5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:02.203387 [ 15982 ] {b9947ae8-6c03-4fec-b707-4585d8b38cb9} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52644) (comment: 03030_system_flush_distributed_settings.sql) (in query: DROP DATABASE IF EXISTS test_mdjr5gj0 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:02.216308 [ 15982 ] {b9947ae8-6c03-4fec-b707-4585d8b38cb9} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:02.227526 [ 16690 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0): (while reading prefix of column json): (while reading from part /var/lib/clickhouse/store/348/348b0315-b637-461f-97ea-b70806246421/all_1_2_2/ in table test_5.test (348b0315-b637-461f-97ea-b70806246421) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039eea4f2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:376: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::NameAndTypePair const&, unsigned long, unsigned long, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::function)::$_1, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039eef7c6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5f53f0 12. ./build_docker/./src/DataTypes/Serializations/SerializationObject.cpp:361: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f71ed91 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:378: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, unsigned long, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::function) @ 0x0000000039eec505 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:397: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>)::$_0::operator()() const @ 0x0000000039eee612 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::unordered_map, std::hash, std::equal_to, std::allocator>>> std::__function::__policy_invoker, std::hash, std::equal_to, std::allocator>>> ()>::__call_impl[abi:ne190107] (DB::NameAndTypePair const&)>)::$_0, std::unordered_map, std::hash, std::equal_to, std::allocator>>> ()>>(std::__function::__policy_storage const*) @ 0x0000000039eef964 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039ef67ce 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:420: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>) @ 0x0000000039eecc0a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:427: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee7933 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c358f91 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 31. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:02.313470 [ 16203 ] {5070086a-5e4a-42e1-a4da-e2f4583c5d8b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:00a4d253-9f1b-4e51-a528-7e3f3d8d68a2'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52820) (comment: 01122_totals_rollup_having_block_header.sql) (in query: CREATE DATABASE IF NOT EXISTS test_hf83yy4o ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:02.321420 [ 16203 ] {5070086a-5e4a-42e1-a4da-e2f4583c5d8b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:00a4d253-9f1b-4e51-a528-7e3f3d8d68a2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:02.591177 [ 16223 ] {b1339933-2a60-47a0-8a2d-0427ac7c9851} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:ead34447-36e8-4c69-8c79-dae79dff1fbd'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52844) (comment: 02945_blake3_msan.sql) (in query: CREATE DATABASE IF NOT EXISTS test_r2gh2i2r ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:02.611768 [ 16223 ] {b1339933-2a60-47a0-8a2d-0427ac7c9851} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:ead34447-36e8-4c69-8c79-dae79dff1fbd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:02.944077 [ 18771 ] {2380aeb3-43fa-485a-9d03-a8b189174161} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:7a656c96-a955-4c4b-8990-4e9d2794113e'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52850) (comment: 02998_attach_partition_not_allowed_if_structure_differs_due_to_materialized_column.sql) (in query: CREATE DATABASE IF NOT EXISTS test_f4xkgp38 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:02.951867 [ 18771 ] {2380aeb3-43fa-485a-9d03-a8b189174161} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:7a656c96-a955-4c4b-8990-4e9d2794113e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:03.041504 [ 2997 ] {f644f0ca-9550-4d4f-bb38-8294bc94e348} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:2ab9f91f-eb56-4c15-bffe-4501a7aa6d3d'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52876) (comment: 00756_power_alias.sql) (in query: CREATE DATABASE IF NOT EXISTS test_rnqm9j78 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:03.048990 [ 2997 ] {f644f0ca-9550-4d4f-bb38-8294bc94e348} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:2ab9f91f-eb56-4c15-bffe-4501a7aa6d3d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:03.141341 [ 18771 ] {15471c61-1712-4be2-952e-9a94e55e5931} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:06918c0d-2f5f-402f-b928-39062fc90b63'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52884) (comment: 02562_with_fill_nullable.sql) (in query: CREATE DATABASE IF NOT EXISTS test_68vfzpt2 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:03.147879 [ 18771 ] {15471c61-1712-4be2-952e-9a94e55e5931} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:06918c0d-2f5f-402f-b928-39062fc90b63'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:03.234292 [ 16223 ] {840a8100-50d5-4928-a280-fa5ed2b13849} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48442) (comment: 01093_cyclic_defaults_filimonov.sql) (query 1, line 1) (in query: CREATE TABLE test ( `a0` UInt64 DEFAULT a1 + 1, `a1` UInt64 DEFAULT a0 + 1, `a2` UInt64 DEFAULT a3 + a4, `a3` UInt64 DEFAULT a2 + 1, `a4` UInt64 ALIAS a3 + 1 ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033712acd 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 19. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 20. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 21. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 22. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:20:03.245861 [ 16223 ] {} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033712acd 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 19. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 20. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 21. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 22. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 26. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:20:03.307108 [ 16223 ] {4455d246-b8ae-47c2-b90a-49fbc1e3a10f} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48442) (comment: 01093_cyclic_defaults_filimonov.sql) (query 2, line 11) (in query: CREATE TABLE pythagoras ( `a` Float64 DEFAULT sqrt((c * c) - (b * b)), `b` Float64 DEFAULT sqrt((c * c) - (a * a)), `c` Float64 DEFAULT sqrt((a * a) + (b * b)) ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033712acd 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 20. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 21. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 22. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 23. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 24. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 25. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 26. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 27. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 29. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 30. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 2025.11.13 09:20:03.314293 [ 18728 ] {c328c6eb-cfa4-4f32-a78c-1d15182ab6fa} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:09a8498a-73c1-46d8-85cb-96951dfa1a4d'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52898) (comment: 01034_values_parse_float_bug.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ml0foygi ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:03.316842 [ 16223 ] {} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033712acd 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 20. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 21. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 22. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146cd 23. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 24. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 25. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 26. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 27. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 29. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 30. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 2025.11.13 09:20:03.322860 [ 18728 ] {c328c6eb-cfa4-4f32-a78c-1d15182ab6fa} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:09a8498a-73c1-46d8-85cb-96951dfa1a4d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:03.504841 [ 2997 ] {36e64472-2812-414b-9205-fba826c494a3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:4e44ffbc-6e54-4b33-b32c-d40cb79c9d45'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52900) (comment: 03276_null_format_matching_case_insensitive.sh) (in query: CREATE DATABASE IF NOT EXISTS test_zay2ewot ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:03.510960 [ 2997 ] {36e64472-2812-414b-9205-fba826c494a3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:4e44ffbc-6e54-4b33-b32c-d40cb79c9d45'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:03.560878 [ 16203 ] {791b2e98-abbb-4b71-a0bb-d94c0ef427e2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:484007dd-2e0b-4471-bb03-a2e9ba26a646'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52904) (comment: 03208_groupArrayIntersect_serialization.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lvxwmkoq ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:03.566570 [ 16203 ] {791b2e98-abbb-4b71-a0bb-d94c0ef427e2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:484007dd-2e0b-4471-bb03-a2e9ba26a646'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:03.666332 [ 18771 ] {152f6dc3-8e91-4e43-b8ab-3c4524dfca2b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:be9b6f29-1a16-498d-8d6a-561caf10fce2'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52918) (comment: 01710_projections_optimize_aggregation_in_order.sh) (in query: CREATE DATABASE IF NOT EXISTS test_59rwwkg0 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:03.675518 [ 18771 ] {152f6dc3-8e91-4e43-b8ab-3c4524dfca2b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:be9b6f29-1a16-498d-8d6a-561caf10fce2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:03.766138 [ 16223 ] {39ebf1d6-46fb-463b-9c5a-3dc6c9d7eaba} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:4a08a190-e182-42bf-8b53-6be9fdbbc286'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52924) (comment: 01533_quantile_deterministic_assert.sql) (in query: CREATE DATABASE IF NOT EXISTS test_l4r7ov8g ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:03.771883 [ 16223 ] {39ebf1d6-46fb-463b-9c5a-3dc6c9d7eaba} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:4a08a190-e182-42bf-8b53-6be9fdbbc286'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:03.865159 [ 18771 ] {fe143df0-02dc-472a-99be-ec63e24e6939} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:517e8487-5772-4397-a4f7-0b2fe19a3b95'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52928) (comment: 03064_analyzer_named_subqueries.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nyls1hb9 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:03.871625 [ 18771 ] {fe143df0-02dc-472a-99be-ec63e24e6939} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:517e8487-5772-4397-a4f7-0b2fe19a3b95'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:03.927784 [ 18721 ] {9b773bc9-7c83-45d7-9626-cc60821a2e53} executeQuery: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading 4. (S3_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48306) (comment: 02752_forbidden_headers.sql) (query 20, line 26) (in query: SELECT * FROM s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:8123/123/4', LineAsString, headers('random_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/IO/S3Common.h:34: DB::S3Exception::S3Exception(Aws::S3::S3Errors, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000002d8ca9ab 4. ./build_docker/./src/IO/S3/getObjectInfo.cpp:105: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool) @ 0x000000002d8c9c13 5. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:363: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x000000002d8aa878 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:867: DB::StorageObjectStorageSource::KeysIterator::next(unsigned long) @ 0x000000002d59f93c 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:47: DB::StorageObjectStorageCluster::getPathSample(DB::StorageInMemoryMetadata, std::shared_ptr) @ 0x000000002d492ba1 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:75: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x000000002d494323 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x0000000026961410 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002695e06a 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 12. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:03.942691 [ 18721 ] {} TCPHandler: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading 4. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/IO/S3Common.h:34: DB::S3Exception::S3Exception(Aws::S3::S3Errors, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x000000002d8ca9ab 4. ./build_docker/./src/IO/S3/getObjectInfo.cpp:105: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool) @ 0x000000002d8c9c13 5. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:363: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x000000002d8aa878 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:867: DB::StorageObjectStorageSource::KeysIterator::next(unsigned long) @ 0x000000002d59f93c 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:47: DB::StorageObjectStorageCluster::getPathSample(DB::StorageInMemoryMetadata, std::shared_ptr) @ 0x000000002d492ba1 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageCluster.cpp:75: DB::StorageObjectStorageCluster::StorageObjectStorageCluster(String const&, std::shared_ptr, std::shared_ptr, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, std::shared_ptr) @ 0x000000002d494323 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, std::shared_ptr&, 0>(std::allocator const&, String const&, std::shared_ptr&, std::shared_ptr&, DB::StorageID&&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, std::shared_ptr&) @ 0x0000000026961410 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionObjectStorageCluster::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002695e06a 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 12. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:04.061101 [ 16203 ] {ab242a5f-4763-4a67-b6a3-2b614eca31f9} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:b0224fcf-e5de-4ba3-9684-bd5c3480361c'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52942) (comment: 00976_shard_low_cardinality_achimbab.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ly7jgxpi ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:04.071920 [ 16203 ] {ab242a5f-4763-4a67-b6a3-2b614eca31f9} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:b0224fcf-e5de-4ba3-9684-bd5c3480361c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:04.200891 [ 16223 ] {41d3ae1b-1a69-4125-8dec-2b002c28c34f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:b903ac41-72a9-44d0-8e8a-db91f5a1832d'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52950) (comment: 02713_ip4_uint_compare.sql) (in query: CREATE DATABASE IF NOT EXISTS test_efk02tzc ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:04.208685 [ 16223 ] {41d3ae1b-1a69-4125-8dec-2b002c28c34f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:b903ac41-72a9-44d0-8e8a-db91f5a1832d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:04.319488 [ 2997 ] {c84c9783-aed9-43e5-ab17-ad3732805886} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:ea855cf7-83d5-493c-a4dd-27e962926517'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52962) (comment: 02122_parallel_formatting_TSKV.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ufsvv1ll ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:04.325461 [ 2997 ] {c84c9783-aed9-43e5-ab17-ad3732805886} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:ea855cf7-83d5-493c-a4dd-27e962926517'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:04.382838 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 888.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:04.383672 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 888.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:04.415247 [ 17388 ] {52c69182-13a2-49c1-8d5c-590461368541} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 886.14 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33182) (comment: 00181_aggregate_functions_statistics.sql) (query 43, line 222) (in query: SELECT quantileExactIf(toFloat64(number) , number > 100) FROM numbers(90);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:20:04.435933 [ 17388 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 886.14 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:04.516139 [ 18728 ] {a7f2eb16-1872-48ec-aae8-e44240d3a22b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:a4519d11-70ca-4dcc-8b08-8b47e9fa73a2'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52966) (comment: 01074_h3_range_check.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lfg1045f ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:04.525852 [ 18728 ] {a7f2eb16-1872-48ec-aae8-e44240d3a22b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:a4519d11-70ca-4dcc-8b08-8b47e9fa73a2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:04.655732 [ 19499 ] {d81f7a04-404b-474c-a868-bd63927261b3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:cb31717a-5272-438a-88b7-6cf481b7f654'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52988) (comment: 00930_max_partitions_per_insert_block.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0cf2c528 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:04.663264 [ 19499 ] {d81f7a04-404b-474c-a868-bd63927261b3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:cb31717a-5272-438a-88b7-6cf481b7f654'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:04.735905 [ 3735 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_104_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 885.11 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:04.761694 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_104_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 885.11 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:04.760073 [ 18728 ] {c187cfaa-d4a8-4bad-aa67-f0b8f453341e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:0d1c3ebb-df0e-497e-8d16-f0dfdc86901a'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53004) (comment: 03278_revoke_implicit_grants.sh) (in query: CREATE DATABASE IF NOT EXISTS test_boqf24sn ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:04.848943 [ 18728 ] {c187cfaa-d4a8-4bad-aa67-f0b8f453341e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:0d1c3ebb-df0e-497e-8d16-f0dfdc86901a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:04.954327 [ 16233 ] {a1150b6d-2481-4661-b81d-c968cc6b5c8b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:282c50a2-3034-4886-8844-6575b66f3855'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53024) (comment: 01271_optimize_arithmetic_operations_in_aggr_func_with_alias.sql) (in query: CREATE DATABASE IF NOT EXISTS test_83c3fipq ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:05.024968 [ 16233 ] {a1150b6d-2481-4661-b81d-c968cc6b5c8b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:282c50a2-3034-4886-8844-6575b66f3855'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:05.306848 [ 18728 ] {e5e73cc3-e293-4d0a-a57e-8387c3f68563} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:bbfeca6d-80e3-4863-b705-51f77d3e1de6'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53032) (comment: 00149_quantiles_timing_distributed.sql) (in query: CREATE DATABASE IF NOT EXISTS test_hw7eabm2 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:05.326531 [ 18728 ] {e5e73cc3-e293-4d0a-a57e-8387c3f68563} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:bbfeca6d-80e3-4863-b705-51f77d3e1de6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:05.434442 [ 2997 ] {c8042953-4cb1-4ac3-9d18-05ad072474d0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:f5417d8f-adeb-4c23-a823-24e4ba864318'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53038) (comment: 01527_clickhouse_local_optimize.sh) (in query: CREATE DATABASE IF NOT EXISTS test_cxgehd5h ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:05.444111 [ 2997 ] {c8042953-4cb1-4ac3-9d18-05ad072474d0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:f5417d8f-adeb-4c23-a823-24e4ba864318'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:05.589643 [ 18771 ] {faafe793-6faa-454e-bf1e-aeae980c5be6} executeQuery: Code: 128. DB::Exception: Too large array size in GenerateRandom: 9223372036854775807, maximum: 1073741824. (TOO_LARGE_ARRAY_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48450) (comment: 01352_generate_random_overflow.sql) (query 1, line 1) (in query: SELECT i FROM generateRandom('i Array(Nullable(Enum8(\'hello\' = 1, \'world\' = 5)))', 1025, 65535, 9223372036854775807) LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b2043ed 4. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:634: DB::StorageGenerateRandom::StorageGenerateRandom(DB::StorageID const&, DB::ColumnsDescription const&, String const&, unsigned long, unsigned long, std::optional const&) @ 0x000000003859b206 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, String, unsigned long const&, unsigned long const&, std::optional const&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, String&&, unsigned long const&, unsigned long const&, std::optional const&) @ 0x000000002678e050 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002678d433 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 8. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:20:05.607009 [ 18771 ] {} TCPHandler: Code: 128. DB::Exception: Too large array size in GenerateRandom: 9223372036854775807, maximum: 1073741824. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b2043ed 4. ./build_docker/./src/Storages/StorageGenerateRandom.cpp:634: DB::StorageGenerateRandom::StorageGenerateRandom(DB::StorageID const&, DB::ColumnsDescription const&, String const&, unsigned long, unsigned long, std::optional const&) @ 0x000000003859b206 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, DB::ColumnsDescription&, String, unsigned long const&, unsigned long const&, std::optional const&, 0>(std::allocator const&, DB::StorageID&&, DB::ColumnsDescription&, String&&, unsigned long const&, unsigned long const&, std::optional const&) @ 0x000000002678e050 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002678d433 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 8. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 22. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 23. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 25. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 28. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:20:05.639835 [ 18728 ] {c31a10d4-0515-4cc9-b7cf-4072e7ef5ba3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:126e13be-d79e-4fcd-8904-c15986934300'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53050) (comment: 03312_check_table_grant.sh) (in query: CREATE DATABASE IF NOT EXISTS test_o6iql7d1 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:05.649073 [ 18728 ] {c31a10d4-0515-4cc9-b7cf-4072e7ef5ba3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:126e13be-d79e-4fcd-8904-c15986934300'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:05.759489 [ 17383 ] {fa8aa430-580e-48ec-8b72-dbe580e1a236} executeQuery: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48434) (comment: 02812_pointwise_array_operations.sql) (query 14, line 14) (in query: SELECT ([12,13] % [5,6]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001599730a 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000014f47c39 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:05.767740 [ 17383 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Array(UInt8) and Array(UInt8) of arguments of function modulo: In scope SELECT [12, 13] % [5, 6]. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001599730a 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000014f47c39 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:05.806142 [ 17383 ] {d83e6f79-0f62-45c4-b3f9-49b8f7007d6a} executeQuery: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48434) (comment: 02812_pointwise_array_operations.sql) (query 15, line 15) (in query: SELECT ([2,3,4]-[1,-2,10,29]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b352d7 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000014b2b5bc 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b231f8 7. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b1f40d 8. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b3411a 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000014b2b5bc 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b231f8 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b1f40d 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:20:05.812261 [ 17383 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments for function minus must have equal sizes: In scope SELECT [2, 3, 4] - [1, -2, 10, 29]. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b352d7 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000014b2b5bc 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b231f8 7. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b1f40d 8. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b3411a 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000014b2b5bc 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b231f8 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014b1f40d 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:20:05.872155 [ 18728 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 897.45 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:05.873142 [ 18728 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 897.45 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:05.899411 [ 16233 ] {1425ef7f-69ef-4cd5-b275-081b0c1aeaf7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:e3986780-9c43-42d9-a1c3-4be7fbcd81c1'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53052) (comment: 01302_aggregate_state_exception_memory_leak.sh) (in query: CREATE DATABASE IF NOT EXISTS test_3ckik4hr ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:05.906321 [ 16233 ] {1425ef7f-69ef-4cd5-b275-081b0c1aeaf7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:e3986780-9c43-42d9-a1c3-4be7fbcd81c1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:05.960500 [ 18728 ] {05bb8d58-4ad6-4d11-942d-413fc5fb7e6c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:75b00e79-f035-4e13-a941-da65536b8d1d'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53060) (comment: 01889_postgresql_protocol_null_fields.sh) (in query: CREATE DATABASE IF NOT EXISTS test_tp1rcbrv ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:05.973029 [ 18728 ] {05bb8d58-4ad6-4d11-942d-413fc5fb7e6c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:75b00e79-f035-4e13-a941-da65536b8d1d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:05.975397 [ 17268 ] {44fc3e42-4650-4416-b490-1fa03b3ab35b} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.16 MiB (attempt to allocate chunk of 3.75 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48446) (comment: 03094_grouparraysorted_memory.sql) (query 4, line 36) (in query: INSERT INTO 03094_grouparrysorted_src SELECT * FROM generateRandom() LIMIT 500000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnDecimal::reserve(unsigned long) @ 0x0000000037211c8e 12. DB::IColumn::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x000000002c15723f 13. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec073 14. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 15. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.001334 [ 3726 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_104_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 897.53 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:06.003026 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_104_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 897.53 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:06.032923 [ 16233 ] {6cccbe99-1a39-4e22-8ec0-51f955860212} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:28ac8b0f-7960-4003-8652-242441cf5d4b'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53070) (comment: 00007_uniq.sql) (in query: CREATE DATABASE IF NOT EXISTS test_4tftry6x ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.038983 [ 17268 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.16 MiB (attempt to allocate chunk of 3.75 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnDecimal::reserve(unsigned long) @ 0x0000000037211c8e 12. DB::IColumn::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x000000002c15723f 13. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec073 14. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 15. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.039161 [ 16233 ] {6cccbe99-1a39-4e22-8ec0-51f955860212} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:28ac8b0f-7960-4003-8652-242441cf5d4b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:06.080335 [ 17383 ] {017c70ed-c905-4c39-b710-4f95a27b4e33} executeQuery: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48434) (comment: 02812_pointwise_array_operations.sql) (query 18, line 18) (in query: SELECT x, y, x+y FROM a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018828477 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001881ff5c 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001881846b 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.152882 [ 17383 ] {} TCPHandler: Code: 190. DB::Exception: Two arguments for function plus must have equal sizes: while executing 'FUNCTION plus(__table1.x :: 2, __table1.y : 0) -> plus(__table1.x, __table1.y) Array(UInt64) : 3'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000018828477 5. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001881ff5c 6. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001881846b 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 13. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.195560 [ 18728 ] {65739969-51c2-4ec9-8f8a-91609b76341d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:22a6ad0e-d74b-4125-accc-e95247889f38'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53084) (comment: 02845_threads_count_in_distributed_queries.gen.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ko6mi56a ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.205852 [ 18728 ] {65739969-51c2-4ec9-8f8a-91609b76341d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:22a6ad0e-d74b-4125-accc-e95247889f38'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:06.304320 [ 16233 ] {606a631c-05da-441a-abbe-164df9c2fa15} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:3c5b3b8d-eaec-4304-8865-61a33478cb97'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53088) (comment: 01010_pmj_right_table_memory_limits.sql) (in query: CREATE DATABASE IF NOT EXISTS test_i4j9td4i ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.316509 [ 16233 ] {606a631c-05da-441a-abbe-164df9c2fa15} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:3c5b3b8d-eaec-4304-8865-61a33478cb97'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:06.545033 [ 16693 ] {dc9e64b3-2c66-41e1-9076-f8b5488a3bd9} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:bb0be927-3f44-42ba-a68b-8dd748207ffd'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53106) (comment: 03272_bitmapTransform_error_counter.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zqf4b8bv ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.550962 [ 16693 ] {dc9e64b3-2c66-41e1-9076-f8b5488a3bd9} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:bb0be927-3f44-42ba-a68b-8dd748207ffd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:06.682046 [ 18131 ] {b8819df1-b293-48b9-9b88-69c6556fbe39} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:14079253-27a5-40a3-a599-9c0f83a73a76'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53126) (comment: 02240_tskv_schema_inference_bug.sh) (in query: CREATE DATABASE IF NOT EXISTS test_d6ys00nw ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.692230 [ 18131 ] {b8819df1-b293-48b9-9b88-69c6556fbe39} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:14079253-27a5-40a3-a599-9c0f83a73a76'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:06.808954 [ 16693 ] {488e7faa-3b4a-49bf-977f-a00d7c762c87} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:c2f75719-086f-4a9b-829e-23c8dc5a676b'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53140) (comment: 02477_projection_materialize_and_zero_copy.sql) (in query: CREATE DATABASE IF NOT EXISTS test_cbmp4zds ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.815355 [ 16693 ] {488e7faa-3b4a-49bf-977f-a00d7c762c87} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:c2f75719-086f-4a9b-829e-23c8dc5a676b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:06.886930 [ 2997 ] {b11da3dc-08a2-4ab2-a75d-be771a00e88e} executeQuery: Code: 174. DB::Exception: Self referencing of `x` to `x`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48516) (comment: 01902_self_aliases_in_columns.sql) (query 1, line 1) (in query: CREATE TABLE a (`number` UInt64, `x` MATERIALIZED x) ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 13681, min_bytes_for_wide_part = 1008990014, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 110, min_bytes_for_full_part_storage = 141542889, compact_parts_max_bytes_to_buffer = 418598698, compact_parts_max_granules_to_buffer = 192, compact_parts_merge_max_bytes_to_prefetch_part = 2861503, merge_max_block_size = 948, old_parts_lifetime = 379., prefer_fetch_merged_part_size_threshold = 6717876922, vertical_merge_algorithm_min_rows_to_activate = 101918, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5014444486, index_granularity_bytes = 8363177, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 30813, primary_key_compress_block_size = 80791, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:89: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003371285d 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 10. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 11. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.941578 [ 2997 ] {} TCPHandler: Code: 174. DB::Exception: Self referencing of `x` to `x`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:89: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003371285d 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 10. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 11. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:20:06.996642 [ 18728 ] {0b5a8586-f33a-4094-b64c-2c5524cce2ac} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:a47fe21a-7656-4f83-871a-f1724b6fc612'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53148) (comment: 00034_aggregate_key_fixed_string.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qbcxhg3l ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:07.003484 [ 18728 ] {0b5a8586-f33a-4094-b64c-2c5524cce2ac} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:a47fe21a-7656-4f83-871a-f1724b6fc612'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.083098 [ 18131 ] {9937f935-5ac7-4a9d-a6d4-858be8580c6a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:a5cb2e09-7de2-4cb7-b785-59cac5085385'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53150) (comment: 01852_dictionary_query_count_long.sql) (in query: CREATE DATABASE IF NOT EXISTS test_46zxskrk ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:07.155155 [ 18131 ] {9937f935-5ac7-4a9d-a6d4-858be8580c6a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:a5cb2e09-7de2-4cb7-b785-59cac5085385'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.221511 [ 18728 ] {c7a58b01-5fdf-4afa-8d88-71202ed24d7a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:70d85151-615b-4563-abe6-f6d81ea876c1'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53160) (comment: 02960_partition_by_udf.sql) (in query: CREATE DATABASE IF NOT EXISTS test_szeun1b3 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:07.271267 [ 18728 ] {c7a58b01-5fdf-4afa-8d88-71202ed24d7a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:70d85151-615b-4563-abe6-f6d81ea876c1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.368329 [ 16693 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 913.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.369451 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 913.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.370476 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 913.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.411475 [ 3732 ] {bec05b16-8cc5-473e-b911-49dd0c849dc9::all_1_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 910.77 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.418924 [ 16693 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 877.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.419683 [ 16693 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 877.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.429208 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bec05b16-8cc5-473e-b911-49dd0c849dc9::all_1_6_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 910.77 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.466445 [ 16693 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.540665 [ 3729 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_104_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 926.30 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.542940 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_104_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 926.30 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.748775 [ 18131 ] {3fec9971-6b08-4f92-b802-a1c24f2861f8} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 878.14 MiB (attempt to allocate chunk of 1.32 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48540) (comment: 00123_shard_unmerged_result_when_max_distributed_connections_is_one.sql) (query 2, line 4) (in query: SELECT count() + 1 FROM remote('127.0.0.{2,3}', system, one);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 18. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:20:07.769733 [ 18131 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 878.14 MiB (attempt to allocate chunk of 1.32 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 18. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:20:07.938935 [ 3728 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_65_69_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 861.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_68_68_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 43): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:07.940811 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_65_69_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 861.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_68_68_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 43): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:08.068522 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 28 entries up to offset 1361: Code: 241. DB::Exception: (total) memory limit exceeded: would use 867.13 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:08.507472 [ 2997 ] {e4bcd344-806e-471f-8cd0-93822bbfb761} executeQuery: Code: 174. DB::Exception: Self referencing of `j` to `j`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48516) (comment: 01902_self_aliases_in_columns.sql) (query 2, line 9) (in query: CREATE TABLE foo (`i` Int32, `j` ALIAS j + 1) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 13681, min_bytes_for_wide_part = 1008990014, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 110, min_bytes_for_full_part_storage = 141542889, compact_parts_max_bytes_to_buffer = 418598698, compact_parts_max_granules_to_buffer = 192, compact_parts_merge_max_bytes_to_prefetch_part = 2861503, merge_max_block_size = 948, old_parts_lifetime = 379., prefer_fetch_merged_part_size_threshold = 6717876922, vertical_merge_algorithm_min_rows_to_activate = 101918, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5014444486, index_granularity_bytes = 8363177, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 30813, primary_key_compress_block_size = 80791, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:89: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003371285d 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 10. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 11. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 12. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 13. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:20:08.581704 [ 2997 ] {} TCPHandler: Code: 174. DB::Exception: Self referencing of `j` to `j`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:89: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003371285d 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000033714143 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337189de 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x00000000337181b1 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000337146e0 10. ./src/Interpreters/QueryNormalizer.h:84: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x000000003361f304 11. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1527: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000336245ac 12. ./build_docker/./src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edb1f 13. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:20:08.606909 [ 16354 ] {63106528-6444-4acf-9b53-5079380065b9} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:7a3dcd2e-2d8c-4e07-9065-6c479aa1c9ef'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53198) (comment: 00142_system_columns.sql) (in query: CREATE DATABASE IF NOT EXISTS test_iv72o8ld ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:08.676086 [ 16354 ] {63106528-6444-4acf-9b53-5079380065b9} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:7a3dcd2e-2d8c-4e07-9065-6c479aa1c9ef'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:08.862718 [ 16352 ] {927fa5a5-a08f-48cb-b4fa-caeeb4643ba1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:7eb07856-3468-4cdf-9dd9-694b87c1c6dc'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53214) (comment: 01778_mmap_cache_infra.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0kuh2kco ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:08.871315 [ 16352 ] {927fa5a5-a08f-48cb-b4fa-caeeb4643ba1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:7eb07856-3468-4cdf-9dd9-694b87c1c6dc'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:08.948763 [ 16047 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:08.949689 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:08.964807 [ 16605 ] {b0899744-94a2-4ce4-b54b-916dd09814e0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:227454f8-3393-49ed-b275-ebf7da323e08'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53228) (comment: 01417_freeze_partition_verbose_zookeeper.sh) (in query: CREATE DATABASE IF NOT EXISTS test_f0ynyh8n ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:08.979758 [ 16605 ] {b0899744-94a2-4ce4-b54b-916dd09814e0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:227454f8-3393-49ed-b275-ebf7da323e08'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:08.986264 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:08.987043 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 872.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:09.010607 [ 3733 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 874.08 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:09.012169 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 874.08 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:09.196437 [ 6072 ] {700935dd-f763-4a81-a573-fdcb4297b365} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 913.59 MiB (attempt to allocate chunk of 3.81 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48488) (comment: 02428_index_analysis_with_null_literal.sql) (query 3, line 6) (in query: insert into test select number, number, '2022-01-01 00:00:00' from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87525a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned int const*, unsigned int const*) @ 0x000000001f8755dd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037afd8c1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8a9c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 22. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 30. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 2025.11.13 09:20:09.236484 [ 6072 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 913.59 MiB (attempt to allocate chunk of 3.81 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87525a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned int const*, unsigned int const*) @ 0x000000001f8755dd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037afd8c1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8a9c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 22. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 30. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:09.845469 [ 18149 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 878.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:09.846370 [ 18149 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 878.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:10.167017 [ 16344 ] {44408218-bea1-435d-9267-e27c5e63b63b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:cec95aa4-dcd2-440b-ab5f-944a31b0cd1d'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53266) (comment: 01903_ssd_cache_dictionary_array_type.sh) (in query: CREATE DATABASE IF NOT EXISTS test_phlgxtqh ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:10.185892 [ 18106 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 888.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:10.186688 [ 18106 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 888.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:10.187125 [ 16344 ] {44408218-bea1-435d-9267-e27c5e63b63b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:cec95aa4-dcd2-440b-ab5f-944a31b0cd1d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:10.620086 [ 18106 ] {0bd09735-ce97-41f0-9052-dfdacf4089af} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:dc01a935-7185-4fe5-ad5b-8cb3f133faaf'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53284) (comment: 02962_system_sync_replica_lightweight_from_modifier.sh) (in query: CREATE DATABASE IF NOT EXISTS test_hc7x5sam ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:10.627331 [ 18106 ] {0bd09735-ce97-41f0-9052-dfdacf4089af} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:dc01a935-7185-4fe5-ad5b-8cb3f133faaf'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:10.635413 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 894.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:10.644436 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 892.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:10.651286 [ 3732 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 894.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:10.652452 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 892.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:10.654456 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 894.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.125901 [ 16352 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.126393 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.126762 [ 16352 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.128512 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.177206 [ 19171 ] {ad8c95a5-036a-4ffd-a4bd-9ecd993ddc33} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55056) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_01516_test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:11.190246 [ 19171 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:11.483808 [ 3730 ] {bec05b16-8cc5-473e-b911-49dd0c849dc9::all_1_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 872.96 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column v): (while reading from part /var/lib/clickhouse/store/bec/bec05b16-8cc5-473e-b911-49dd0c849dc9/all_4_4_0/ in table test_9.test (bec05b16-8cc5-473e-b911-49dd0c849dc9) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. ./src/Common/HashTable/HashTable.h:538: HashTable, DB::ColumnString, true, true>, DB::ReverseIndexHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x00000000379cd67b 12. ./src/Common/HashTable/HashTable.h:926: DB::ReverseIndex::insert(StringRef) @ 0x0000000037874a37 13. ./src/Columns/ColumnUnique.h:602: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long) @ 0x00000000379cf839 14. ./src/Columns/ColumnUnique.h:569: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long)::'lambda'(unsigned long&)::operator()(unsigned long&) const @ 0x00000000379ce711 15. ./src/Columns/ColumnUnique.h:605: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long) @ 0x00000000379c7dc5 16. ./src/Columns/ColumnUnique.h:653: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long)::'lambda'(auto)::operator()(auto) const @ 0x0000000037870541 17. ./src/Columns/ColumnUnique.h:661: DB::ColumnUnique::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003786fb54 18. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:267: DB::ColumnLowCardinality::insertRangeFromDictionaryEncodedColumn(DB::IColumn const&, DB::IColumn const&) @ 0x000000003754068b 19. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:612: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69cda4 20. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:499: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f824ac6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 27. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.515045 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bec05b16-8cc5-473e-b911-49dd0c849dc9::all_1_6_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 872.96 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column v): (while reading from part /var/lib/clickhouse/store/bec/bec05b16-8cc5-473e-b911-49dd0c849dc9/all_4_4_0/ in table test_9.test (bec05b16-8cc5-473e-b911-49dd0c849dc9) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. ./src/Common/HashTable/HashTable.h:538: HashTable, DB::ColumnString, true, true>, DB::ReverseIndexHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x00000000379cd67b 12. ./src/Common/HashTable/HashTable.h:926: DB::ReverseIndex::insert(StringRef) @ 0x0000000037874a37 13. ./src/Columns/ColumnUnique.h:602: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long) @ 0x00000000379cf839 14. ./src/Columns/ColumnUnique.h:569: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long)::'lambda'(unsigned long&)::operator()(unsigned long&) const @ 0x00000000379ce711 15. ./src/Columns/ColumnUnique.h:605: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long) @ 0x00000000379c7dc5 16. ./src/Columns/ColumnUnique.h:653: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long)::'lambda'(auto)::operator()(auto) const @ 0x0000000037870541 17. ./src/Columns/ColumnUnique.h:661: DB::ColumnUnique::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003786fb54 18. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:267: DB::ColumnLowCardinality::insertRangeFromDictionaryEncodedColumn(DB::IColumn const&, DB::IColumn const&) @ 0x000000003754068b 19. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:612: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69cda4 20. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:499: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f824ac6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 27. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.772435 [ 16352 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: std::shared_ptr std::make_shared[abi:ne190107]&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003ad9a8ef 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003ad7b96d 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.779704 [ 16605 ] {d3804707-6887-4fee-92cb-0fa125a1fd8a} mysqlxx::Pool: Failed to connect to MySQL (test_y2hl4x62@127.0.0.1:9004 as user default): mysqlxx::ConnectionFailed 2025.11.13 09:20:11.798631 [ 16605 ] {d3804707-6887-4fee-92cb-0fa125a1fd8a} Application: Connection to test_y2hl4x62@127.0.0.1:9004 as user default failed: mysqlxx::ConnectionFailed: Lost connection to MySQL server at 'handshake: reading inital communication packet', system error: 11 ((nullptr):0) 2025.11.13 09:20:11.808126 [ 16605 ] {d3804707-6887-4fee-92cb-0fa125a1fd8a} Application: Connection to mysql failed 1 times 2025.11.13 09:20:11.832702 [ 16354 ] {547ad80d-7a80-4a10-aeb1-8439d4a03f45} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:53455f1c-8d09-44ea-a145-0ebac8069242'. (REPLICA_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48518) (comment: 02166_arrow_dictionary_inference.sh) (in query: CREATE DATABASE IF NOT EXISTS test_3ib6w025 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:11.839327 [ 16354 ] {547ad80d-7a80-4a10-aeb1-8439d4a03f45} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: 'd32b9e83770c:9000:cce2d5a1-781a-4283-89b9-fd26751b23d1', current host ID: 'd32b9e83770c:9000:53455f1c-8d09-44ea-a145-0ebac8069242'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&, String&, String&, String&, String&) @ 0x000000002fa2dca7 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x000000002f9a0457 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000002f9b4314 6. ./build_docker/./src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000032a4ebd4 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b95d7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.932337 [ 16693 ] {fca53762-e5cb-4658-8cd0-d150bd6bf006} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 895.95 MiB (attempt to allocate chunk of 1.18 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: while receiving packet from 127.0.0.5:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48560) (comment: 02941_variant_type_3.sh) (query 1, line 2) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:499: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f824ac6 16. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003b0c9858 17. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003aab1aca 18. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003aaac195 19. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 20. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 22. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 23. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:20:11.950861 [ 17227 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37264, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.951479 [ 17227 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37264, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.964607 [ 16192 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45512, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.965240 [ 16192 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45512, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:11.995957 [ 16693 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 895.95 MiB (attempt to allocate chunk of 1.18 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: while receiving packet from 127.0.0.5:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:499: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f824ac6 16. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003b0c9858 17. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003aab1aca 18. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003aaac195 19. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 20. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 22. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 23. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:12.411138 [ 3737 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_71_14} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 861.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: (while reading column ProfileEvent_ZooKeeperBytesReceived): (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_1_66_13/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 730): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:12.412804 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_71_14}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 861.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: (while reading column ProfileEvent_ZooKeeperBytesReceived): (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_1_66_13/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 730): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:12.758150 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 902.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:12.759009 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 902.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:12.857803 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 886.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:12.888782 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_90_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 902.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:12.891591 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_90_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 902.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:12.931397 [ 3735 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.57 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:12.933214 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.57 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:13.432862 [ 3739 ] {bec05b16-8cc5-473e-b911-49dd0c849dc9::all_1_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 900.54 MiB (attempt to allocate chunk of 1.19 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/bec/bec05b16-8cc5-473e-b911-49dd0c849dc9/all_6_6_0/data.bin (position: 68915, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 8a24fa11a941ea86bf8d26a5f887359d827c06000053a00500): (while reading column v): (while reading from part /var/lib/clickhouse/store/bec/bec05b16-8cc5-473e-b911-49dd0c849dc9/all_6_6_0/ in table test_9.test (bec05b16-8cc5-473e-b911-49dd0c849dc9) located on disk default of type local, from mark 1 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 16. ./src/IO/ReadHelpers.h:117: DB::SerializationVariant::deserializeDiscriminatorsStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x000000002f81f2a8 17. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:181: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f81d5e9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:290: DB::MergeTreeReaderCompact::readPrefix(DB::NameAndTypePair const&, std::shared_ptr const&, std::shared_ptr&, std::function const&) @ 0x0000000039e8f707 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:274: DB::MergeTreeReaderCompact::readPrefix(unsigned long, DB::MergeTreeReaderStream&) @ 0x0000000039e8ef62 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:52: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed659b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:13.434882 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bec05b16-8cc5-473e-b911-49dd0c849dc9::all_1_6_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 900.54 MiB (attempt to allocate chunk of 1.19 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/bec/bec05b16-8cc5-473e-b911-49dd0c849dc9/all_6_6_0/data.bin (position: 68915, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 8a24fa11a941ea86bf8d26a5f887359d827c06000053a00500): (while reading column v): (while reading from part /var/lib/clickhouse/store/bec/bec05b16-8cc5-473e-b911-49dd0c849dc9/all_6_6_0/ in table test_9.test (bec05b16-8cc5-473e-b911-49dd0c849dc9) located on disk default of type local, from mark 1 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 16. ./src/IO/ReadHelpers.h:117: DB::SerializationVariant::deserializeDiscriminatorsStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x000000002f81f2a8 17. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:181: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f81d5e9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:290: DB::MergeTreeReaderCompact::readPrefix(DB::NameAndTypePair const&, std::shared_ptr const&, std::shared_ptr&, std::function const&) @ 0x0000000039e8f707 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:274: DB::MergeTreeReaderCompact::readPrefix(unsigned long, DB::MergeTreeReaderStream&) @ 0x0000000039e8ef62 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:52: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed659b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.348826 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1902 entries up to offset 362573: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.27 MiB (attempt to allocate chunk of 4.04 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.570894 [ 3730 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 851.43 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.573237 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 851.43 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.647611 [ 16887 ] {2bd33944-60d8-4a80-b0e9-dc1422514a7d} GraceHashJoin: Can't create bucket 0 due to error: Code: 241. DB::Exception: (total) memory limit exceeded: would use 851.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.662822 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 848.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.663703 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 848.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.737568 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 848.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.738451 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 848.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.739310 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 848.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.802314 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 848.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:14.803186 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 848.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.016916 [ 3726 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.23 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.018644 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.23 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.232885 [ 16352 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 860.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: std::shared_ptr std::make_shared[abi:ne190107]&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003ad9a8ef 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003ad7b96d 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.240346 [ 16605 ] {705a8a81-10c8-45fd-8a08-6cdceb8cdb01} mysqlxx::Pool: Failed to connect to MySQL (test_y2hl4x62@127.0.0.1:9004 as user default): mysqlxx::ConnectionFailed 2025.11.13 09:20:15.240544 [ 16605 ] {705a8a81-10c8-45fd-8a08-6cdceb8cdb01} Application: Connection to test_y2hl4x62@127.0.0.1:9004 as user default failed: mysqlxx::ConnectionFailed: Lost connection to MySQL server at 'handshake: reading inital communication packet', system error: 11 ((nullptr):0) 2025.11.13 09:20:15.240726 [ 16605 ] {705a8a81-10c8-45fd-8a08-6cdceb8cdb01} Application: Connection to mysql failed 1 times 2025.11.13 09:20:15.242386 [ 16352 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 860.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: std::shared_ptr std::make_shared[abi:ne190107]&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003ad9a8ef 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003ad7b96d 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.242996 [ 16605 ] {705a8a81-10c8-45fd-8a08-6cdceb8cdb01} mysqlxx::Pool: Failed to connect to MySQL (test_y2hl4x62@127.0.0.1:9004 as user default): mysqlxx::ConnectionFailed 2025.11.13 09:20:15.243161 [ 16605 ] {705a8a81-10c8-45fd-8a08-6cdceb8cdb01} Application: Connection to test_y2hl4x62@127.0.0.1:9004 as user default failed: mysqlxx::ConnectionFailed: Lost connection to MySQL server at 'handshake: reading inital communication packet', system error: 11 ((nullptr):0) 2025.11.13 09:20:15.243238 [ 16605 ] {705a8a81-10c8-45fd-8a08-6cdceb8cdb01} Application: Connection to mysql failed 2 times 2025.11.13 09:20:15.244768 [ 16352 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 860.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: std::shared_ptr std::make_shared[abi:ne190107]&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003ad9a8ef 13. ./build_docker/./src/Server/MySQLHandler.cpp:241: DB::MySQLHandler::run() @ 0x000000003ad7b96d 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.245322 [ 16605 ] {705a8a81-10c8-45fd-8a08-6cdceb8cdb01} mysqlxx::Pool: Failed to connect to MySQL (test_y2hl4x62@127.0.0.1:9004 as user default): mysqlxx::ConnectionFailed 2025.11.13 09:20:15.245462 [ 16605 ] {705a8a81-10c8-45fd-8a08-6cdceb8cdb01} Application: Connection to test_y2hl4x62@127.0.0.1:9004 as user default failed: mysqlxx::ConnectionFailed: Lost connection to MySQL server at 'handshake: reading inital communication packet', system error: 11 ((nullptr):0) 2025.11.13 09:20:15.245517 [ 16605 ] {705a8a81-10c8-45fd-8a08-6cdceb8cdb01} Application: Connection to mysql failed 3 times 2025.11.13 09:20:15.446838 [ 3736 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.59 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.453308 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_105_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.59 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.489909 [ 19171 ] {bec05b16-8cc5-473e-b911-49dd0c849dc9::all_1_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 856.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column v): (while reading from part /var/lib/clickhouse/store/bec/bec05b16-8cc5-473e-b911-49dd0c849dc9/all_2_2_0/ in table test_9.test (bec05b16-8cc5-473e-b911-49dd0c849dc9) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:156: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be286 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:499: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f824ac6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.501096 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 863.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.502002 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 863.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.519275 [ 19171 ] {35906c1e-ba18-430a-92b9-4e536bf15ca2} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 856.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column v): (while reading from part /var/lib/clickhouse/store/bec/bec05b16-8cc5-473e-b911-49dd0c849dc9/all_2_2_0/ in table test_9.test (bec05b16-8cc5-473e-b911-49dd0c849dc9) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55112) (comment: 02941_variant_type_3.sh) (query 1, line 1) (in query: optimize table test final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:156: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be286 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:499: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f824ac6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 2025.11.13 09:20:15.535468 [ 19171 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 856.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column v): (while reading from part /var/lib/clickhouse/store/bec/bec05b16-8cc5-473e-b911-49dd0c849dc9/all_2_2_0/ in table test_9.test (bec05b16-8cc5-473e-b911-49dd0c849dc9) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:156: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be286 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:499: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f824ac6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 2025.11.13 09:20:15.554843 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_91_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.45 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.556506 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_91_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.45 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.585933 [ 16887 ] {2bd33944-60d8-4a80-b0e9-dc1422514a7d} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 851.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41720) (comment: 03006_join_on_inequal_expression_2.gen.sql) (query 65, line 84) (in query: SELECT t1.*, t2.* FROM t1 INNER JOIN t2 ON t1.key = t2.key AND (t2.a BETWEEN 8 AND t1.a) ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::WrapperGuard::WrapperGuard>(std::unique_ptr>, std::shared_ptr&&) @ 0x0000000033567da3 14. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x00000000335630c4 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::TemporaryBlockStreamHolder::TemporaryBlockStreamHolder(DB::Block const&, std::shared_ptr, unsigned long) @ 0x0000000033566197 16. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:394: DB::GraceHashJoin::addBuckets(unsigned long) @ 0x000000003291feec 17. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:281: DB::GraceHashJoin::initBuckets() @ 0x000000003291e4b7 18. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:428: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930831 19. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 20. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 21. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 22. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ee447 24. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 25. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:20:15.597711 [ 16887 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 851.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::WrapperGuard::WrapperGuard>(std::unique_ptr>, std::shared_ptr&&) @ 0x0000000033567da3 14. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x00000000335630c4 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::TemporaryBlockStreamHolder::TemporaryBlockStreamHolder(DB::Block const&, std::shared_ptr, unsigned long) @ 0x0000000033566197 16. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:394: DB::GraceHashJoin::addBuckets(unsigned long) @ 0x000000003291feec 17. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:281: DB::GraceHashJoin::initBuckets() @ 0x000000003291e4b7 18. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:428: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930831 19. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 20. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 21. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 22. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ee447 24. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 25. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:20:15.608579 [ 18149 ] {7d917692-3bf6-4a79-a1eb-ca2c80eeff89} TemporaryFileOnLocalDisk: Temporary path 'tmp31db1b03-2e7b-453d-ada0-9629db23496c' does not exist in '/tmp/clickhouse/' on disk _tmp_default 2025.11.13 09:20:15.617640 [ 18149 ] {7d917692-3bf6-4a79-a1eb-ca2c80eeff89} GraceHashJoin: Can't create bucket 0 due to error: Code: 241. DB::Exception: (total) memory limit exceeded: would use 858.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:15.637523 [ 16344 ] {59710f79-eec0-461e-9753-7d344c3914e7} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55128) (comment: 02869_insert_filenames_collisions.sql) (query 3, line 5) (in query: CREATE TABLE t_collisions (`very_very_long_column_name_that_will_be_replaced_with_hash` Int32, `e798545eefc8b7a1c2c81ff00c064ad8` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS replace_long_file_name_to_hash = 1, max_file_name_length = 42, index_granularity = 14475, min_bytes_for_wide_part = 827288575, ratio_of_defaults_for_sparse_serialization = 0., min_bytes_for_full_part_storage = 444731961, compact_parts_max_bytes_to_buffer = 136150151, compact_parts_max_granules_to_buffer = 136, compact_parts_merge_max_bytes_to_prefetch_part = 22440764, merge_max_block_size = 22099, old_parts_lifetime = 317., prefer_fetch_merged_part_size_threshold = 3969062305, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 55, min_merge_bytes_to_use_direct_io = 5732954778, index_granularity_bytes = 11700974, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 29, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 73171, primary_key_compress_block_size = 59897, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:527: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003985c311 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a49609f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a495477 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a487422 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:20:15.646088 [ 16344 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:527: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003985c311 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a49609f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a495477 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a487422 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:20:16.169296 [ 16605 ] {705a8a81-10c8-45fd-8a08-6cdceb8cdb01} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: test_y2hl4x62@127.0.0.1:9004 as user default, ERROR 2013 : mysqlxx::ConnectionFailed: Lost connection to MySQL server at 'handshake: reading inital communication packet', system error: 11 ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48606) (comment: 02479_mysql_connect_to_self.sql) (query 9, line 16) (in query: SELECT count() FROM mysql('127.0.0.1:9004', currentDatabase(), foo, 'default', '[HIDDEN]', SETTINGS connect_timeout = 100, connection_wait_timeout = 100)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000412aa414 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002fe0aafe 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000003886a67f 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x0000000038869415 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000267fd8e0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000267fb8fa 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:16.175781 [ 16605 ] {} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: test_y2hl4x62@127.0.0.1:9004 as user default, ERROR 2013 : mysqlxx::ConnectionFailed: Lost connection to MySQL server at 'handshake: reading inital communication packet', system error: 11 ((nullptr):0). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:277: mysqlxx::PoolWithFailover::get() @ 0x00000000412aa414 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:94: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000002fe0aafe 6. ./build_docker/./src/Storages/StorageMySQL.cpp:98: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x000000003886a67f 7. ./build_docker/./src/Storages/StorageMySQL.cpp:80: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x0000000038869415 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, 0>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x00000000267fd8e0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000267fb8fa 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:16.446243 [ 18149 ] {7d917692-3bf6-4a79-a1eb-ca2c80eeff89} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 858.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48628) (comment: 01495_subqueries_in_with_statement.sql) (query 13, line 22) (in query: WITH test1 AS (SELECT number-1 as n FROM numbers(42)) SELECT max(n+1)+1 z FROM test1 join test1 x using n having z - 1 = (select min(n-1)+41 from test1) + 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:133: DB::TemporaryFileOnLocalDisk::write() @ 0x000000003356c8ba 18. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x0000000033562f6a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::TemporaryBlockStreamHolder::TemporaryBlockStreamHolder(DB::Block const&, std::shared_ptr, unsigned long) @ 0x0000000033566197 20. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:394: DB::GraceHashJoin::addBuckets(unsigned long) @ 0x000000003291feec 21. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:281: DB::GraceHashJoin::initBuckets() @ 0x000000003291e4b7 22. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:428: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930831 23. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 24. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 25. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 26. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ee447 28. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 29. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 2025.11.13 09:20:16.460556 [ 18149 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 858.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:133: DB::TemporaryFileOnLocalDisk::write() @ 0x000000003356c8ba 18. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x0000000033562f6a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::TemporaryBlockStreamHolder::TemporaryBlockStreamHolder(DB::Block const&, std::shared_ptr, unsigned long) @ 0x0000000033566197 20. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:394: DB::GraceHashJoin::addBuckets(unsigned long) @ 0x000000003291feec 21. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:281: DB::GraceHashJoin::initBuckets() @ 0x000000003291e4b7 22. ./build_docker/./src/Interpreters/GraceHashJoin.cpp:428: DB::GraceHashJoin::initialize(DB::Block const&) @ 0x0000000032930831 23. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:28: DB::JoiningTransform::transformHeader(DB::Block, std::shared_ptr const&) @ 0x000000003bb21790 24. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:204: DB::JoinStep::updateOutputHeader() @ 0x000000003c17abc8 25. ./build_docker/./src/Processors/QueryPlan/IQueryPlanStep.cpp:26: DB::IQueryPlanStep::updateInputHeaders(std::vector>) @ 0x000000003c144d57 26. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:97: DB::JoinStep::JoinStep(DB::Block const&, DB::Block const&, std::shared_ptr, unsigned long, unsigned long, unsigned long, std::unordered_set, std::equal_to, std::allocator>, bool, bool) @ 0x000000003c1742c1 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ee447 28. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 29. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 2025.11.13 09:20:16.465652 [ 9835 ] {9dcacb41-36d9-435d-996d-1784e1a1bbae} StorageBuffer (test_1hzza0oj.part_01278_5): Caught exception while adding data to buffer, rolling back...: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.95 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 6. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 7. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::ColumnNullable::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000375efe1e 14. ./src/Columns/IColumn.h:210: DB::BufferSink::insertIntoBuffer(DB::Block const&, DB::StorageBuffer::Buffer&, int) @ 0x0000000038fc664b 15. ./build_docker/./src/Storages/StorageBuffer.cpp:738: DB::BufferSink::consume(DB::Chunk&) @ 0x0000000038fc42e4 16. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 17. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 24. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:16.984597 [ 16344 ] {abeed4bc-bd1b-4c0d-8e3d-d56123dfa932} executeQuery: Code: 36. DB::Exception: Columns 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' and 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' have streams (very_very_long_column_name_that_will_be_replaced_with_hash and e798545eefc8b7a1c2c81ff00c064ad8) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55128) (comment: 02869_insert_filenames_collisions.sql) (query 6, line 25) (in query: ALTER TABLE t_collisions ADD COLUMN very_very_long_column_name_that_will_be_replaced_with_hash Int32;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7706: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x000000003993c0a4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3914: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003991fa09 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:17.000678 [ 16344 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' and 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' have streams (very_very_long_column_name_that_will_be_replaced_with_hash and e798545eefc8b7a1c2c81ff00c064ad8) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7706: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x000000003993c0a4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3914: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003991fa09 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:17.056551 [ 16344 ] {6469bae7-d15b-4f40-b772-6f06c85d46b1} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55128) (comment: 02869_insert_filenames_collisions.sql) (query 7, line 26) (in query: ALTER TABLE t_collisions RENAME COLUMN col1 TO very_very_long_column_name_that_will_be_replaced_with_hash;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7706: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x000000003993c0a4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3914: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003991fa09 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:17.072525 [ 16344 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7706: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x000000003993c0a4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3914: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003991fa09 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:17.132152 [ 3738 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_65_69_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 894.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_68_68_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 43): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.133905 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_65_69_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 894.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_68_68_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 43): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.220411 [ 3728 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 897.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.222046 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 897.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.355779 [ 19171 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 871.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.356664 [ 19171 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 871.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.430971 [ 19171 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.431799 [ 19171 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.432218 [ 16231 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.433023 [ 16231 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.447807 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 873.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.465006 [ 19171 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 875.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.465798 [ 19171 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 875.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:17.654427 [ 16344 ] {8ce21283-c629-4155-9f8d-cbefe3c0ffa2} executeQuery: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55128) (comment: 02869_insert_filenames_collisions.sql) (query 11, line 41) (in query: ALTER TABLE t_collisions MODIFY SETTING replace_long_file_name_to_hash = 1, max_file_name_length = 42;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7706: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x000000003993c0a4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3914: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003991fa09 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:17.659116 [ 18106 ] {36e521fa-cfc2-4341-94c0-094a9c1a5e68} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.16 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION plus(__table1.number : 0, 1_UInt8 :: 1) -> plus(__table1.number, 1_UInt8) UInt64 : 4'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55102) (comment: 02122_parallel_formatting_TSVWithNames.sh) (query 1, line 1) (in query: select number, number + 1, concat('string: ', toString(number)) from numbers(200000) group by number with totals order by number limit 190000 format TSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000188bc760 13. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x00000000188bb930 14. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000188b9ed9 15. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001882985f 16. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001881feb2 17. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001881846b 18. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188146cd 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:20:17.666133 [ 16344 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'e798545eefc8b7a1c2c81ff00c064ad8 Int32' and 'very_very_long_column_name_that_will_be_replaced_with_hash Int32' have streams (e798545eefc8b7a1c2c81ff00c064ad8 and very_very_long_column_name_that_will_be_replaced_with_hash) with collision in file name e798545eefc8b7a1c2c81ff00c064ad8. It may be a collision between a filename for one column and a hash of filename for another column (see setting 'replace_long_file_name_to_hash'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7706: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x000000003993c0a4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3914: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003991fa09 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:17.710400 [ 18106 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.16 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION plus(__table1.number : 0, 1_UInt8 :: 1) -> plus(__table1.number, 1_UInt8) UInt64 : 4'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000188bc760 13. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x00000000188bb930 14. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000188b9ed9 15. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001882985f 16. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001881feb2 17. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001881846b 18. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000188146cd 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:18.099514 [ 16047 ] {732e0595-14f2-4388-a1ce-8efb4b09d36a} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.04 MiB (attempt to allocate chunk of 1.39 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: while receiving packet from 127.0.0.4:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55188) (comment: 02941_variant_type_3.sh) (query 1, line 2) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f8267a6 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003b0c9858 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003aab1aca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003aaac195 15. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:20:18.123068 [ 4170 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:53004, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:18.123678 [ 4170 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:53004, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:18.188429 [ 16047 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.04 MiB (attempt to allocate chunk of 1.39 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: while receiving packet from 127.0.0.4:9000: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationVariant::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f8267a6 12. ./build_docker/./src/Formats/NativeReader.cpp:97: DB::NativeReader::read() @ 0x000000003b0c9858 13. ./build_docker/./src/Client/Connection.cpp:1362: DB::Connection::receiveDataImpl(DB::NativeReader&) @ 0x000000003aab1aca 14. ./build_docker/./src/Client/Connection.cpp:1343: DB::Connection::receivePacket() @ 0x000000003aaac195 15. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 17. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 18. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 19. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:18.217681 [ 16231 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:18.218719 [ 16231 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:18.312998 [ 16141 ] {e6c746ef-de2d-4868-a1ec-e7aae1a78f41} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:58564). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:18.774546 [ 16344 ] {b4dc111c-8a6c-4ede-8d38-6938b3d9be3f} executeQuery: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name col.size0. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55128) (comment: 02869_insert_filenames_collisions.sql) (query 15, line 49) (in query: CREATE TABLE t_collisions (`id` Int, `col` Array(String), `col.s` Array(LowCardinality(String)), `col.u` Array(LowCardinality(String))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 14475, min_bytes_for_wide_part = 827288575, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 444731961, compact_parts_max_bytes_to_buffer = 136150151, compact_parts_max_granules_to_buffer = 136, compact_parts_merge_max_bytes_to_prefetch_part = 22440764, merge_max_block_size = 22099, old_parts_lifetime = 317., prefer_fetch_merged_part_size_threshold = 3969062305, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 55, min_merge_bytes_to_use_direct_io = 5732954778, index_granularity_bytes = 11700974, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 29, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 73171, primary_key_compress_block_size = 59897, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:527: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003985c311 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a49609f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a495477 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a487422 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:20:18.786043 [ 16344 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name col.size0. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:527: DB::MergeTreeData::MergeTreeData(DB::StorageID const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::LoadingStrictnessLevel, std::function) @ 0x000000003985c311 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:146: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000003a49609f 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, 0>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x000000003a495477 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a487422 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:20:19.091773 [ 16186 ] {9dcacb41-36d9-435d-996d-1784e1a1bbae} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60025.276215 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41660) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (query 1, line 2) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:20:19.145396 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 875.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:19.148107 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 875.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:19.151309 [ 3739 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 875.84 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column input_bytes): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_95_4/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8354): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:19.153423 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 875.84 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column input_bytes): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_95_4/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8354): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:19.174950 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 868.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:19.179583 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 868.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:19.244832 [ 3731 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 872.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:19.254148 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 872.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:19.470155 [ 16344 ] {dde76330-31ae-44cb-8654-56dd6dc8ba03} executeQuery: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name col.size0. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55128) (comment: 02869_insert_filenames_collisions.sql) (query 18, line 71) (in query: ALTER TABLE t_collisions MODIFY COLUMN col Array(String);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7706: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x000000003993c0a4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3914: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003991fa09 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:19.486006 [ 16344 ] {} TCPHandler: Code: 36. DB::Exception: Columns 'col Nested(s LowCardinality(String), u LowCardinality(String))' and 'col Array(String)' have streams (col.size0 and col.size0) with collision in file name col.size0. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7756: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::ColumnsDescription const&, DB::MergeTreeSettings const&, bool) const @ 0x0000000039868d7f 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7706: DB::MergeTreeData::checkColumnFilenamesForCollision(DB::StorageInMemoryMetadata const&, bool) const @ 0x000000003993c0a4 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3914: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003991fa09 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991167 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:19.572604 [ 16186 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60025.276215 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:20.075772 [ 3738 ] {bec05b16-8cc5-473e-b911-49dd0c849dc9::all_1_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x000000003978b547 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x00000000397c379c 6. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c3402 7. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 8. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 9. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:20.882470 [ 3739 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 863.97 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:20.884506 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 863.97 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:21.010614 [ 3724 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_71_14} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 854.50 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_1_66_13/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 730): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:21.017050 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_71_14}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 854.50 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_1_66_13/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 730): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:21.055763 [ 3733 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 853.40 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column input_bytes): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_95_4/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 1 with max_rows_to_read = 8848): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:21.059130 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 853.40 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column input_bytes): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_95_4/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 1 with max_rows_to_read = 8848): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:21.325688 [ 16054 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 852.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:21.326527 [ 16054 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 852.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:21.385478 [ 16054 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 852.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:21.386368 [ 16054 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 852.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.163062 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 881.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.164113 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 881.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.209196 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 879.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.323632 [ 3726 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 879.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.330161 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 879.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.352779 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 874.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.353679 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 874.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.389454 [ 3735 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 872.38 MiB (attempt to allocate chunk of 1.34 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_95_4/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8354): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.391493 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 872.38 MiB (attempt to allocate chunk of 1.34 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_95_4/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8354): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.470133 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 871.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.470961 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 871.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.681980 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 867.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.682722 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 867.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.869859 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.873146 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.888233 [ 3730 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.03 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:22.889925 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.03 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:23.085000 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 863.03 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:23.085905 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 863.03 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:23.105236 [ 19171 ] {69603e2e-3d17-4322-9527-4c28d1860004} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 866.02 MiB (attempt to allocate chunk of 4.13 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55276) (comment: 00104_totals_having_mode.sql) (query 8, line 10) (in query: SELECT number, count() FROM (SELECT * FROM system.numbers LIMIT 100000) GROUP BY number WITH TOTALS HAVING number % 3 = 0 ORDER BY number LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x000000003201db8d 12. ./src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003214366c 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003213f6ad 14. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031e9276f 15. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031ca8e7b 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb4455 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:20:23.148813 [ 19171 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 866.02 MiB (attempt to allocate chunk of 4.13 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x000000003201db8d 12. ./src/Common/HashTable/HashTable.h:926: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003214366c 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003213f6ad 14. ./build_docker/./src/Interpreters/Aggregator.cpp:946: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031e9276f 15. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031ca8e7b 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb4455 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:23.157056 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 837.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:23.158028 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 837.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:23.650708 [ 16054 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 847.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:23.651499 [ 16054 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 847.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:23.676637 [ 3732 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 850.12 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:23.683483 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 850.12 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:23.758593 [ 16354 ] {ddbdc623-73df-4613-a078-196667e309ad} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.03 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55200) (comment: 01788_update_nested_type_subcolumn_check.sql) (query 10, line 25) (in query: alter table test_wide_nested update `info.id` = [100,200,300], `info.age` = `info.id`, `info.name` = ['a','b','c'] where id = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationEntry.cpp:62: DB::MergeTreeMutationEntry::MergeTreeMutationEntry(DB::MutationCommands, std::shared_ptr, String const&, unsigned long, DB::TransactionID const&, DB::WriteSettings const&) @ 0x000000003a556e18 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:572: DB::StorageMergeTree::startMutation(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4a938d 19. ./build_docker/./src/Storages/StorageMergeTree.cpp:716: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b58bd 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:20:23.817427 [ 16354 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 862.03 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationEntry.cpp:62: DB::MergeTreeMutationEntry::MergeTreeMutationEntry(DB::MutationCommands, std::shared_ptr, String const&, unsigned long, DB::TransactionID const&, DB::WriteSettings const&) @ 0x000000003a556e18 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:572: DB::StorageMergeTree::startMutation(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4a938d 19. ./build_docker/./src/Storages/StorageMergeTree.cpp:716: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b58bd 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:20:24.019305 [ 17385 ] {d8e5d8bf-dc84-4103-88ae-5c8f2fe8bab5} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 861.02 MiB (attempt to allocate chunk of 2.01 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55362) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (query 1, line 2) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x00000000376e93c2 12. ./build_docker/./src/Columns/ColumnNullable.cpp:751: DB::ColumnNullable::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x00000000375fbe0c 13. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec073 14. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 15. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 24. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:20:24.179338 [ 17385 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 861.02 MiB (attempt to allocate chunk of 2.01 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x00000000376e93c2 12. ./build_docker/./src/Columns/ColumnNullable.cpp:751: DB::ColumnNullable::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x00000000375fbe0c 13. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec073 14. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 15. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 24. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:24.523289 [ 18392 ] {1f49dc6a-dc5b-433d-8cbd-b3059bb01256} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39428) (comment: 02047_log_family_complex_structs_data_file_dumps.sh) (query 1, line 1) (in query: INSERT INTO tbl VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x00000000387943bc 18. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::LogSink::onFinish() @ 0x0000000038f3ef61 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0ec2f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d7fc 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 26. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 27. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:20:24.558751 [ 18392 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 859.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Common/FileChecker.cpp:142: DB::FileChecker::save() const @ 0x00000000387943bc 18. ./build_docker/./src/Storages/StorageLog.cpp:790: DB::LogSink::onFinish() @ 0x0000000038f3ef61 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0ec2f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d7fc 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 26. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 27. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:20:24.596633 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_91_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 850.18 MiB (attempt to allocate chunk of 1.13 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergingSortedTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037add219 13. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:0: DB::ColumnLowCardinality::Index::insertPositionsRange(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003752f6ae 14. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:220: DB::ColumnLowCardinality::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003752d1a3 15. ./src/Columns/IColumn.h:210: DB::ColumnTuple::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037779980 16. ./src/Columns/IColumn.h:210: DB::ColumnArray::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x000000003709f2e8 17. ./src/Columns/IColumn.h:198: DB::ColumnMap::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x00000000375e5cff 18. ./src/Columns/IColumn.h:198: DB::MergedData::insertRow(std::vector> const&, unsigned long, unsigned long) @ 0x000000003beb032f 19. ./build_docker/./src/Processors/Merges/Algorithms/MergingSortedAlgorithm.cpp:205: DB::IMergingAlgorithm::Status DB::MergingSortedAlgorithm::mergeImpl>(DB::SortingQueueImpl&) @ 0x000000003bf79d39 20. ./build_docker/./src/Processors/Merges/Algorithms/MergingSortedAlgorithm.cpp:123: _ZNSt3__116__variant_detail12__visitation6__base12__dispatcherIJLm26EEE10__dispatchB8ne190107IONS1_9__variant15__value_visitorIRZN2DB22MergingSortedAlgorithm5mergeEvE3$_0EEJRNS0_6__baseILNS0_6_TraitE1EJNS8_16SortingQueueImplINS8_33SpecializedSingleColumnSortCursorINS8_12ColumnVectorIDuEEEELNS8_20SortingQueueStrategyE0EEENSG_INSH_INSI_ItEEEELSL_0EEENSG_INSH_INSI_IjEEEELSL_0EEENSG_INSH_INSI_ImEEEELSL_0EEENSG_INSH_INSI_IN4wide7integerILm128EjEEEEEELSL_0EEENSG_INSH_INSI_INSX_ILm256EjEEEEEELSL_0EEENSG_INSH_INSI_IDB8_EEEELSL_0EEENSG_INSH_INSI_IsEEEELSL_0EEENSG_INSH_INSI_IiEEEELSL_0EEENSG_INSH_INSI_IlEEEELSL_0EEENSG_INSH_INSI_INSX_ILm128EiEEEEEELSL_0EEENSG_INSH_INSI_INSX_ILm256EiEEEEEELSL_0EEENSG_INSH_INSI_I8BFloat16EEEELSL_0EEENSG_INSH_INSI_IfEEEELSL_0EEENSG_INSH_INSI_IdEEEELSL_0EEENSG_INSH_INS8_13ColumnDecimalINS8_7DecimalIiEEEEEELSL_0EEENSG_INSH_INS21_INS22_IlEEEEEELSL_0EEENSG_INSH_INS21_INS22_IS1J_EEEEEELSL_0EEENSG_INSH_INS21_INS22_IS1N_EEEEEELSL_0EEENSG_INSH_INS21_INS8_10DateTime64EEEEELSL_0EEENSG_INSH_INSI_I13StrongTypedefISY_NS8_7UUIDTagEEEEEELSL_0EEENSG_INSH_INSI_INS8_4IPv4EEEEELSL_0EEENSG_INSH_INSI_INS8_4IPv6EEEEELSL_0EEENSG_INSH_INS8_12ColumnStringEEELSL_0EEENSG_INSH_INS8_17ColumnFixedStringEEELSL_0EEENSG_INS8_16SimpleSortCursorELSL_0EEENSG_INS8_10SortCursorELSL_0EEENSG_INS8_23SortCursorWithCollationELSL_0EEEEEEEEEDcT_DpT0_ @ 0x000000003bec4d73 21. ./contrib/llvm-project/libcxx/include/variant:508: DB::MergingSortedAlgorithm::merge() @ 0x000000003beb66eb 22. ./src/Processors/Merges/IMergingTransform.h:137: DB::IMergingTransform::work() @ 0x00000000330e2299 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:24.598438 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_91_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 850.18 MiB (attempt to allocate chunk of 1.13 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergingSortedTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037add219 13. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:0: DB::ColumnLowCardinality::Index::insertPositionsRange(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003752f6ae 14. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:220: DB::ColumnLowCardinality::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003752d1a3 15. ./src/Columns/IColumn.h:210: DB::ColumnTuple::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037779980 16. ./src/Columns/IColumn.h:210: DB::ColumnArray::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x000000003709f2e8 17. ./src/Columns/IColumn.h:198: DB::ColumnMap::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x00000000375e5cff 18. ./src/Columns/IColumn.h:198: DB::MergedData::insertRow(std::vector> const&, unsigned long, unsigned long) @ 0x000000003beb032f 19. ./build_docker/./src/Processors/Merges/Algorithms/MergingSortedAlgorithm.cpp:205: DB::IMergingAlgorithm::Status DB::MergingSortedAlgorithm::mergeImpl>(DB::SortingQueueImpl&) @ 0x000000003bf79d39 20. ./build_docker/./src/Processors/Merges/Algorithms/MergingSortedAlgorithm.cpp:123: _ZNSt3__116__variant_detail12__visitation6__base12__dispatcherIJLm26EEE10__dispatchB8ne190107IONS1_9__variant15__value_visitorIRZN2DB22MergingSortedAlgorithm5mergeEvE3$_0EEJRNS0_6__baseILNS0_6_TraitE1EJNS8_16SortingQueueImplINS8_33SpecializedSingleColumnSortCursorINS8_12ColumnVectorIDuEEEELNS8_20SortingQueueStrategyE0EEENSG_INSH_INSI_ItEEEELSL_0EEENSG_INSH_INSI_IjEEEELSL_0EEENSG_INSH_INSI_ImEEEELSL_0EEENSG_INSH_INSI_IN4wide7integerILm128EjEEEEEELSL_0EEENSG_INSH_INSI_INSX_ILm256EjEEEEEELSL_0EEENSG_INSH_INSI_IDB8_EEEELSL_0EEENSG_INSH_INSI_IsEEEELSL_0EEENSG_INSH_INSI_IiEEEELSL_0EEENSG_INSH_INSI_IlEEEELSL_0EEENSG_INSH_INSI_INSX_ILm128EiEEEEEELSL_0EEENSG_INSH_INSI_INSX_ILm256EiEEEEEELSL_0EEENSG_INSH_INSI_I8BFloat16EEEELSL_0EEENSG_INSH_INSI_IfEEEELSL_0EEENSG_INSH_INSI_IdEEEELSL_0EEENSG_INSH_INS8_13ColumnDecimalINS8_7DecimalIiEEEEEELSL_0EEENSG_INSH_INS21_INS22_IlEEEEEELSL_0EEENSG_INSH_INS21_INS22_IS1J_EEEEEELSL_0EEENSG_INSH_INS21_INS22_IS1N_EEEEEELSL_0EEENSG_INSH_INS21_INS8_10DateTime64EEEEELSL_0EEENSG_INSH_INSI_I13StrongTypedefISY_NS8_7UUIDTagEEEEEELSL_0EEENSG_INSH_INSI_INS8_4IPv4EEEEELSL_0EEENSG_INSH_INSI_INS8_4IPv6EEEEELSL_0EEENSG_INSH_INS8_12ColumnStringEEELSL_0EEENSG_INSH_INS8_17ColumnFixedStringEEELSL_0EEENSG_INS8_16SimpleSortCursorELSL_0EEENSG_INS8_10SortCursorELSL_0EEENSG_INS8_23SortCursorWithCollationELSL_0EEEEEEEEEDcT_DpT0_ @ 0x000000003bec4d73 21. ./contrib/llvm-project/libcxx/include/variant:508: DB::MergingSortedAlgorithm::merge() @ 0x000000003beb66eb 22. ./src/Processors/Merges/IMergingTransform.h:137: DB::IMergingTransform::work() @ 0x00000000330e2299 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:24.778922 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 875.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:24.779879 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 875.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:24.793347 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1064 entries up to offset 364936: Code: 241. DB::Exception: (total) memory limit exceeded: would use 880.18 MiB (attempt to allocate chunk of 4.39 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 10. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 11. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 12. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 13. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 27. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 28. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x000000003335e7be 29. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba3381 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba31bf 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:24.798860 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 869.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:24.799718 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 869.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:24.805862 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 868.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:24.806771 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 868.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:24.869339 [ 3729 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 876.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:24.871594 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 876.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.013894 [ 3726 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 850.13 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column plan_step_name): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_95_4/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8354): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.015511 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 850.13 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column plan_step_name): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_95_4/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8354): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.439830 [ 10170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 841.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.440682 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 841.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.449203 [ 10170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 839.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.450068 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 839.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.488972 [ 10170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 833.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.489962 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 833.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.502671 [ 3733 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 833.88 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.504466 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_100_5}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 833.88 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:25.808624 [ 5803 ] {6754715e-1f9b-469f-9eeb-7a7411ebef4f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 5, line 6) (in query: SELECT snowflakeIDToDateTime();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:25.815052 [ 5803 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:25.844024 [ 5803 ] {6dd010bb-d438-45c6-838b-81ea2e45170d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 6, line 7) (in query: SELECT snowflakeIDToDateTime64();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:25.851507 [ 5803 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:25.887369 [ 5803 ] {8899518a-06d9-428b-a9b9-f8913dae63e6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 7, line 8) (in query: SELECT snowflakeIDToDateTime('invalid_snowflake');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:25.894128 [ 5803 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:25.942755 [ 5803 ] {352453b1-b660-497a-ad2c-8a7a1c268dd0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime64('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 8, line 9) (in query: SELECT snowflakeIDToDateTime64('invalid_snowflake');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:25.979674 [ 5803 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: String: In scope SELECT snowflakeIDToDateTime64('invalid_snowflake'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.072165 [ 5803 ] {c0771141-e40f-449e-a101-8b9f177b3b67} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 9, line 10) (in query: SELECT snowflakeIDToDateTime(123::UInt64, 'invalid_epoch');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.085735 [ 5803 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.204259 [ 5803 ] {e084e446-c901-42ee-89de-13cc3baa1fce} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 10, line 11) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, 'invalid_epoch');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.210295 [ 5803 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: String: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 'invalid_epoch'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.249309 [ 5803 ] {9cd8c40b-12f1-41c1-9033-af78fa7bff58} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 11, line 12) (in query: SELECT snowflakeIDToDateTime(123::UInt64, materialize(42));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.255103 [ 5803 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.410311 [ 5803 ] {fdbb58b9-ec69-4806-833e-50741f4655c5} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 12, line 13) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, materialize(42));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.418238 [ 5803 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'epoch' to function 'snowflakeIDToDateTime64'. Expected: const UInt*, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), materialize(42)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.459356 [ 5803 ] {866fd6d9-72e5-4edd-9ce6-bd7c29ee4add} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 13, line 14) (in query: SELECT snowflakeIDToDateTime(123::UInt64, 42, 42);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.466282 [ 5803 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.505490 [ 5803 ] {d06b344c-8b90-4403-8911-41016020c21b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime64'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 14, line 15) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, 42, 42);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.511997 [ 5803 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'time_zone' to function 'snowflakeIDToDateTime64'. Expected: String, got: UInt8: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 42). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:20:26.519865 [ 3729 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_101_5} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 871.24 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:26.522090 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_101_5}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 871.24 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:26.529968 [ 16054 ] {ca6492dd-2d45-4385-8b55-e55e88ba256d} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 839.61 MiB (attempt to allocate chunk of 1.34 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39508) (comment: 02941_variant_type_3.sh) (query 2, line 3) (in query: insert into test select number + 200000, number % 2 ? NULL : number from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVariant::reserve(unsigned long) @ 0x0000000037a78ea3 12. ./build_docker/./src/Columns/ColumnVariant.cpp:1323: DB::ColumnVariant::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000037a79200 13. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec073 14. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 15. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:20:26.583886 [ 5803 ] {fcadb24d-0d6d-48ec-a034-8f66d77d1a59} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 15, line 16) (in query: SELECT snowflakeIDToDateTime(123::UInt64, 42, 'UTC', 'too_many_args');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:26.590834 [ 5803 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a615e68 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:26.595825 [ 3727 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 871.30 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:26.597795 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 871.30 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:26.616753 [ 16200 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 855.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:26.617741 [ 16200 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 855.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:26.629534 [ 5803 ] {c8faf892-6511-4f7b-966e-bcfc40582c1b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39564) (comment: 01942_snowflakeIDToDateTime.sql) (query 16, line 17) (in query: SELECT snowflakeIDToDateTime64(123::UInt64, 42, 'UTC', 'too_many_args');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:26.647046 [ 5803 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT snowflakeIDToDateTime64(CAST('123', 'UInt64'), 42, 'UTC', 'too_many_args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionSnowflakeIDToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a6183b0 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:20:26.686499 [ 16054 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 839.61 MiB (attempt to allocate chunk of 1.34 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVariant::reserve(unsigned long) @ 0x0000000037a78ea3 12. ./build_docker/./src/Columns/ColumnVariant.cpp:1323: DB::ColumnVariant::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000037a79200 13. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec073 14. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 15. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:27.011982 [ 16054 ] {66b8dd6a-d708-4da9-bcee-b454a9784b3b} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39656) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (query 1, line 1) (in query: drop table if exists null_01278;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:20:27.027672 [ 16054 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:20:27.640440 [ 10170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:27.641226 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:27.656889 [ 10170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 907.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:27.657615 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 907.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:27.676574 [ 3733 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_101_5} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.99 MiB (attempt to allocate chunk of 1.29 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_95_4/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 1 with max_rows_to_read = 8848): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:27.678102 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_101_5}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.99 MiB (attempt to allocate chunk of 1.29 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_95_4/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 1 with max_rows_to_read = 8848): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:27.837537 [ 10170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 905.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:27.838477 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 905.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:27.882740 [ 10170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 902.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:27.883618 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 902.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.096145 [ 3735 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.097789 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_70_106_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.364974 [ 16691 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.365788 [ 16691 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.406518 [ 10170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.417480 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.431759 [ 3731 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_72_13} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.24 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.434644 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_72_13}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 870.24 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.589020 [ 18391 ] {374f3847-3175-49c5-93fd-1d094349ba2e} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.19 MiB (attempt to allocate chunk of 1.62 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39682) (comment: 02941_variant_type_3.sh) (query 1, line 2) (in query: select v from test format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003aa90dc2 18. ./build_docker/./src/Client/ConnectionPool.cpp:103: DB::ConnectionPool::get(DB::ConnectionTimeouts const&, DB::Settings const&, bool) @ 0x000000003aaf0e2c 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:51: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadb565 20. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:108: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107], String const&, DB::Block const&, std::shared_ptr, std::shared_ptr, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::shared_ptr)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f28b236 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 22. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 23. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 24. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 25. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:20:28.600102 [ 5639 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51808, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.600856 [ 5639 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51808, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:28.647503 [ 18391 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 906.19 MiB (attempt to allocate chunk of 1.62 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003aa90dc2 18. ./build_docker/./src/Client/ConnectionPool.cpp:103: DB::ConnectionPool::get(DB::ConnectionTimeouts const&, DB::Settings const&, bool) @ 0x000000003aaf0e2c 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:51: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadb565 20. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:108: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107], String const&, DB::Block const&, std::shared_ptr, std::shared_ptr, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::shared_ptr)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f28b236 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 22. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 23. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 24. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 25. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:28.883989 [ 17228 ] {4c239def-4f4c-4251-819d-a0419b314d5e} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44616) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (in query: DROP DATABASE IF EXISTS test_1hzza0oj SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:28.891393 [ 17228 ] {4c239def-4f4c-4251-819d-a0419b314d5e} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:29.242234 [ 10170 ] {99ac380a-3d94-4110-b212-d6b5ecb9ec02} executeQuery: Code: 57. DB::Exception: Table test_7.tbl already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39744) (comment: 02047_log_family_complex_structs_data_file_dumps.sh) (query 1, line 1) (in query: CREATE TABLE tbl(x Array(Array(Int32)), y Nested(z String, w Float32)) ENGINE=TinyLog), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:20:29.256273 [ 10170 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.tbl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:20:30.434061 [ 19619 ] {0a1cde9a-f86c-4b0b-9f9a-98ad057a3db8} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 855.78 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39512) (comment: 03254_uniq_exact_two_level_negative_zero.sql) (query 1, line 1) (in query: WITH number % 1000 = 0 ? (rand() % 2 ? 0.0 : -0.0) : number::Float64 AS x SELECT length(uniqExactState(x)::String) FROM numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000024786fd7 12. ./src/Common/HashTable/HashTable.h:926: DB::AggregateFunctionUniq>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000247788bf 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000031cae26d 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb43a8 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 16. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:20:30.632934 [ 16200 ] {c82ef596-eba3-490e-81e4-27256cca9590} executeQuery: Code: 33. DB::Exception: Error while parsing Nullable: got an unquoted string n instead of a number: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_3.data): While executing CustomSeparatedRowInputFormat: While executing File. (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39828) (comment: 02130_parse_quoted_null.sh) (query 1, line 1) (in query: select * from file('test_3.data', 'CustomSeparated', 'x Nullable(Float64), y Nullable(UInt64)') settings input_format_parallel_parsing=0, format_custom_escaping_rule='Quoted'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:530: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&)::'lambda0'(DB::IColumn&, DB::ReadBuffer&)::operator()(DB::IColumn&, DB::ReadBuffer&) const @ 0x000000002f6d8531 5. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:211: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000002f6ce150 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:544: DB::SerializationNullable::deserializeTextQuoted(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6c9bde 7. ./build_docker/./src/Formats/EscapingRuleUtils.cpp:117: DB::deserializeFieldByEscapingRule(std::shared_ptr const&, std::shared_ptr const&, DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings::EscapingRule, DB::FormatSettings const&) @ 0x000000003af8be7a 8. ./build_docker/./src/Processors/Formats/Impl/CustomSeparatedRowInputFormat.cpp:295: DB::CustomSeparatedFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003b590335 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e78f 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x000000003851b412 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:20:30.638018 [ 19619 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 855.78 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. ./src/Common/HashTable/HashTable.h:538: HashTable, HashTableNoState>, HashCRC32, TwoLevelHashTableGrower<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x0000000024786fd7 12. ./src/Common/HashTable/HashTable.h:926: DB::AggregateFunctionUniq>::addBatchSinglePlace(unsigned long, unsigned long, char*, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000247788bf 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeWithoutKeyImpl(char*&, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, DB::Arena*, bool) const @ 0x0000000031cae26d 14. ./build_docker/./src/Interpreters/Aggregator.cpp:1575: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb43a8 15. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 16. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:30.659596 [ 16200 ] {} TCPHandler: Code: 33. DB::Exception: Error while parsing Nullable: got an unquoted string n instead of a number: (at row 1) : Could not print diagnostic info because two last rows aren't in buffer (rare case) : (in file/uri /var/lib/clickhouse/user_files/test_3.data): While executing CustomSeparatedRowInputFormat: While executing File. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:530: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&)::'lambda0'(DB::IColumn&, DB::ReadBuffer&)::operator()(DB::IColumn&, DB::ReadBuffer&) const @ 0x000000002f6d8531 5. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:211: void DB::deserializeTextQuotedImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x000000002f6ce150 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:544: DB::SerializationNullable::deserializeTextQuoted(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f6c9bde 7. ./build_docker/./src/Formats/EscapingRuleUtils.cpp:117: DB::deserializeFieldByEscapingRule(std::shared_ptr const&, std::shared_ptr const&, DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings::EscapingRule, DB::FormatSettings const&) @ 0x000000003af8be7a 8. ./build_docker/./src/Processors/Formats/Impl/CustomSeparatedRowInputFormat.cpp:295: DB::CustomSeparatedFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000003b590335 9. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:304: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e78f 10. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 11. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 12. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 18. ./build_docker/./src/Storages/StorageFile.cpp:1480: DB::StorageFileSource::generate() @ 0x000000003851b412 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:33.466738 [ 19606 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:33.467676 [ 19606 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:39.228067 [ 10170 ] {e53f32be-d7ce-4dda-a03d-26d1bc27688d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39782) (comment: 01584_distributed_buffer_cannot_find_column.sql) (query 15, line 27) (in query: DROP TABLE realtimebuff;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:20:39.239316 [ 10170 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:20:40.951055 [ 18721 ] {d22e87bb-6324-4b33-b259-9969660147c4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41166) (comment: 03270_object_to_json_alter_memory.sql) (query 1, line 3) (in query: set allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:41.059083 [ 18721 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:41.781196 [ 18824 ] {ad75307d-dba9-4de0-bb61-2a7d3a1f7af1} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 14. Bytes expected: 39.: (at row 1) : While executing BinaryRowInputFormat. (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39688) (comment: 03350_json_parsing_quickly.sql) (query 1, line 3) (in query: SELECT * FROM format(RowBinary, 'x JSON', substring(base64Decode( 'alNPTgr/DUMnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycwJ////////wNuJycnJycnBQAnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycnAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAACcnJycnJycnJyck/0gFAA==' ), 6)) SETTINGS enable_json_type = 1, type_json_skip_duplicated_paths = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./src/IO/ReadHelpers.h:149: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001f9cfa51 6. ./build_docker/./src/DataTypes/Serializations/SerializationObject.cpp:951: DB::SerializationObject::deserializeBinary(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f73efd8 7. ./build_docker/./src/Processors/Formats/Impl/BinaryRowInputFormat.cpp:136: DB::BinaryRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b3f5521 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 19. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:20:41.796778 [ 18824 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 14. Bytes expected: 39.: (at row 1) : While executing BinaryRowInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./src/IO/ReadHelpers.h:149: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001f9cfa51 6. ./build_docker/./src/DataTypes/Serializations/SerializationObject.cpp:951: DB::SerializationObject::deserializeBinary(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f73efd8 7. ./build_docker/./src/Processors/Formats/Impl/BinaryRowInputFormat.cpp:136: DB::BinaryRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b3f5521 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 19. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:20:41.980555 [ 16235 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:41.981509 [ 16235 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:44.826621 [ 16223 ] {1de6740a-2728-41a3-8590-9aff47cbe201} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57790) (comment: 02880_indexHint__partition_id.sql) (in query: DROP DATABASE IF EXISTS test_xkdxyt72 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:20:44.833205 [ 16223 ] {1de6740a-2728-41a3-8590-9aff47cbe201} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:47.608801 [ 16223 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:20:50.170083 [ 16605 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:50.171241 [ 16605 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:52.006831 [ 6072 ] {97a498d2-2e98-479d-acc4-cfb8d9bacb59} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41354) (comment: 00094_union_race_conditions_5.sh) (query 26, line 26) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:52.032621 [ 6072 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:20:57.768082 [ 16887 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:20:57.769350 [ 16887 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:20:58.178675 [ 16693 ] {4b66039a-8f64-43fb-b3e2-e714774296f2} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$..1key'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59322) (comment: 01889_sql_json_functions.sql) (query 25, line 28) (in query: SELECT JSON_VALUE('{"1key":1}', '$..1key');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c871b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c8556c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:20:58.191499 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$..1key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c871b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c8556c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:20:58.236615 [ 16693 ] {63b4b423-6c40-4821-9e35-54b67308e21a} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$1key'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59322) (comment: 01889_sql_json_functions.sql) (query 26, line 29) (in query: SELECT JSON_VALUE('{"1key":1}', '$1key');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c871b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c8556c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:20:58.244869 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$1key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c871b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c8556c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:20:58.285187 [ 16693 ] {aed968e2-5245-487f-93e9-d216d992e60c} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$key'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59322) (comment: 01889_sql_json_functions.sql) (query 27, line 30) (in query: SELECT JSON_VALUE('{"1key":1}', '$key');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c871b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c8556c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:20:58.291832 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c871b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c8556c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:20:58.328714 [ 16693 ] {d2bbe013-6b21-4fdf-b023-466d508f5ead} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$.[key]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59322) (comment: 01889_sql_json_functions.sql) (query 28, line 31) (in query: SELECT JSON_VALUE('{"1key":1}', '$.[key]');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c871b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c8556c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:20:58.335563 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_VALUE('{"1key":1}', '$.[key]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c871b1 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c8556c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:20:58.715832 [ 16344 ] {c2ccc62b-cf6e-4cd5-acb4-2e56b383ef5e} executeQuery: Code: 43. DB::Exception: Unsupported types for IN. First argument type Tuple(Nothing, Nothing). Second argument type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59420) (comment: 01407_lambda_arrayJoin.sql) (query 3, line 4) (in query: SELECT * FROM system.one ARRAY JOIN arrayFilter((a) -> ((a, arrayJoin([])) IN (NULL)), []) AS arr_x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/SetUtils.cpp:211: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000311543a5 5. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000003117cdf0 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba11 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 9. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003117b8ab 14. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bef988 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:20:58.765399 [ 16344 ] {} TCPHandler: Code: 43. DB::Exception: Unsupported types for IN. First argument type Tuple(Nothing, Nothing). Second argument type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/SetUtils.cpp:211: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000311543a5 5. ./build_docker/./src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000003117cdf0 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba11 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 9. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 11. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 12. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000003117ba23 13. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000003117b8ab 14. ./build_docker/./src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bef988 15. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:21:01.598381 [ 16605 ] {09c47886-4115-42b8-89ed-7529e7cff167} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44660) (comment: 01043_dictionary_attribute_properties_values.sql) (in query: DROP DATABASE IF EXISTS test_t8ygedj6 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:21:01.604484 [ 16605 ] {09c47886-4115-42b8-89ed-7529e7cff167} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:02.143847 [ 3735 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_73_13} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 838.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:02.145698 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_73_13}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 838.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:02.228814 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 838.66 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:02.229819 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 838.66 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:03.405412 [ 16887 ] {8d7b2e27-66c1-4b62-8c24-05d86ed01397} executeQuery: Code: 44. DB::Exception: Cannot drop column `id`, because column `id2` depends on it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56678) (comment: 00575_illegal_column_exception_when_drop_depen_column.sh) (query 1, line 1) (in query: ALTER TABLE test_00575 DROP COLUMN id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1615: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a2f44 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:21:03.419038 [ 16887 ] {} TCPHandler: Code: 44. DB::Exception: Cannot drop column `id`, because column `id2` depends on it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1615: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a2f44 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:21:03.740491 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_96_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 838.74 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:03.742520 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_96_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 838.74 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:04.415323 [ 16693 ] {a8e1ce4b-733d-49a5-bcce-e320bede42b6} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$..1key'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59322) (comment: 01889_sql_json_functions.sql) (query 56, line 60) (in query: SELECT JSON_QUERY('{"1key":1}', '$..1key');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c7c831 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c7ab4c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:21:04.422929 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$..1key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c7c831 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c7ab4c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:21:04.459141 [ 16693 ] {d04cafdd-35f0-48da-9c19-685cabe1b4e5} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$1key'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59322) (comment: 01889_sql_json_functions.sql) (query 57, line 61) (in query: SELECT JSON_QUERY('{"1key":1}', '$1key');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c7c831 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c7ab4c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:21:04.466149 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$1key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c7c831 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c7ab4c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:21:04.556802 [ 16693 ] {cb57a6b0-ac73-49c2-ae7f-e7aa37495177} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$key'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59322) (comment: 01889_sql_json_functions.sql) (query 58, line 62) (in query: SELECT JSON_QUERY('{"1key":1}', '$key');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c7c831 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c7ab4c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:21:04.612086 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$key'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c7c831 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c7ab4c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:21:04.656103 [ 16693 ] {3156bf66-5bba-4378-ad73-ab23e248ea53} executeQuery: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$.[key]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59322) (comment: 01889_sql_json_functions.sql) (query 59, line 63) (in query: SELECT JSON_QUERY('{"1key":1}', '$.[key]');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c7c831 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c7ab4c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:21:04.669032 [ 16693 ] {} TCPHandler: Code: 36. DB::Exception: Unable to parse JSONPath: In scope SELECT JSON_QUERY('{"1key":1}', '$.[key]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionSQLJSONHelpers::Executor>, DB::SimdJSONParser>::run(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int, unsigned int, bool) @ 0x0000000008c7c831 5. DB::FunctionSQLJSON::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c7ab4c 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:21:05.398945 [ 16344 ] {pagaqzkwcv} executeQuery: Code: 60. DB::Exception: Table test_5.input does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56760) (comment: 02765_queries_with_subqueries_profile_events.sh) (query 1, line 1) (in query: INSERT INTO input SELECT * FROM numbers(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:05.414772 [ 16344 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.input does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:09.143112 [ 18106 ] {ceeb7621-a737-469a-82eb-7192c580528e} executeQuery: Code: 80. DB::Exception: Query from view test_7.view_no_nulls returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56798) (comment: 01866_view_persist_settings.sql) (query 14, line 37) (in query: SELECT * FROM view_no_nulls;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageView.cpp:203: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038eabc25 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:21:09.150901 [ 18106 ] {} TCPHandler: Code: 80. DB::Exception: Query from view test_7.view_no_nulls returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageView.cpp:203: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038eabc25 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:21:09.627018 [ 16047 ] {77052aac-1763-4298-ac5f-815208c73c6c} executeQuery: Code: 628. DB::Exception: Can not use OFFSET FETCH clause without ORDER BY. (OFFSET_FETCH_WITHOUT_ORDER_BY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53766) (comment: 02114_offset_fetch_without_order_by.sh) (in query: SELECT number from numbers(10) OFFSET 1 ROWS FETCH FIRST 1 ROWS ONLY;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:430: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e26bc22 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e2c1164 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e13e10c 9. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e11df50 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 11. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e26db31 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 13. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:74: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235a67 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 15. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 16. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 17. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 18. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 19. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 20. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 22. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 23. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 24. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:21:09.635741 [ 16047 ] {77052aac-1763-4298-ac5f-815208c73c6c} DynamicQueryHandler: Code: 628. DB::Exception: Can not use OFFSET FETCH clause without ORDER BY. (OFFSET_FETCH_WITHOUT_ORDER_BY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Parsers/ParserSelectQuery.cpp:430: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e26bc22 5. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 6. ./build_docker/./src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e2c1164 7. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 8. ./build_docker/./src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x000000003e13e10c 9. ./src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e11df50 10. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 11. ./build_docker/./src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e26db31 12. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 13. ./build_docker/./src/Parsers/ParserQueryWithOutput.cpp:74: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e235a67 14. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 15. ./build_docker/./src/Parsers/ParserQuery.cpp:78: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e21f4b3 16. ./build_docker/./src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x000000003e186e9b 17. ./build_docker/./src/Parsers/parseQuery.cpp:321: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x000000003e2f2a13 18. ./build_docker/./src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5a70 19. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 20. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 22. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 23. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 24. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:11.012814 [ 17227 ] {20b949eb-dd88-49ae-bd01-6f38854df092} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02941_variant_type_2.sh) (in query: /* ddl_entry=query-0000000162 */ CREATE TABLE test_11.test UUID 'e4ef4a93-6029-4adc-b664-0c252454cc5e' (`id` UInt64, `v` Variant(Array(UInt64), LowCardinality(String), String, Tuple(a UInt32, b UInt32), UInt64)) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 506383142, compact_parts_max_granules_to_buffer = 107, compact_parts_merge_max_bytes_to_prefetch_part = 30170523, merge_max_block_size = 1400, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 3105005408, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 56835, primary_key_compress_block_size = 45079, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:21:11.071496 [ 17227 ] {20b949eb-dd88-49ae-bd01-6f38854df092} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57838) (comment: 02941_variant_type_2.sh) (query 1, line 1) (in query: CREATE TABLE test (`id` UInt64, `v` Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 100000000, min_bytes_for_wide_part = 1000000000, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 506383142, compact_parts_max_granules_to_buffer = 107, compact_parts_merge_max_bytes_to_prefetch_part = 30170523, merge_max_block_size = 1400, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 3105005408, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 56835, primary_key_compress_block_size = 45079, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:21:11.084528 [ 17227 ] {} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:21:11.914830 [ 4170 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled: while executing 'FUNCTION sleep(1_UInt8 :: 0) -> sleep(1_UInt8) UInt8 : 1'. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001a6035bd 8. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6029ba 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 14. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 15. ./build_docker/./src/Storages/VirtualColumnUtils.cpp:105: DB::VirtualColumnUtils::filterBlockWithExpression(std::shared_ptr const&, DB::Block&) @ 0x0000000038ee4edc 16. ./build_docker/./src/Storages/VirtualColumnUtils.cpp:513: DB::VirtualColumnUtils::filterBlockWithPredicate(DB::ActionsDAG::Node const*, DB::Block&, std::shared_ptr, bool) @ 0x0000000038efb29d 17. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7456: DB::MergeTreeData::getMinMaxCountProjectionBlock(std::shared_ptr const&, std::vector> const&, DB::ActionsDAG const*, std::vector, std::allocator>> const&, std::unordered_map, std::equal_to, std::allocator>> const*, std::shared_ptr) const @ 0x0000000039a0026a 18. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:488: DB::QueryPlanOptimizations::getAggregateProjectionCandidates(DB::QueryPlan::Node&, DB::AggregatingStep&, DB::ReadFromMergeTree&, std::shared_ptr, std::equal_to, std::allocator>>> const&, bool) @ 0x000000003c564f33 19. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:592: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000003c56a812 20. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:196: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c478e 21. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:21:15.649570 [ 18106 ] {ad422810-d50c-4199-844e-664243386ec2} executeQuery: Code: 80. DB::Exception: Query from view test_7.view_no_nulls returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56798) (comment: 01866_view_persist_settings.sql) (query 42, line 73) (in query: SELECT * FROM view_no_nulls;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageView.cpp:203: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038eabc25 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:21:15.658613 [ 18106 ] {} TCPHandler: Code: 80. DB::Exception: Query from view test_7.view_no_nulls returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageView.cpp:203: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038eabc25 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:21:19.222311 [ 18700 ] {80a7a382-3486-4284-9840-abfe012e3c34} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57964) (comment: 02740_hashed_dictionary_load_factor_smoke.sql) (query 22, line 58) (in query: DROP DICTIONARY test_dictionary_load_factor;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:21:19.251025 [ 18700 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:21:19.666294 [ 17385 ] {a5626d00-a3fe-480f-a32a-da67ede96599} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_9/test_01666/replicas/r1). (TABLE_IS_READ_ONLY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57958) (comment: 00623_truncate_all_tables.sql) (query 21, line 27) (in query: TRUNCATE ALL TABLES FROM IF EXISTS test_9), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5932: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000388c391e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6929: DB::StorageReplicatedMergeTree::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038b36406 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:19.683785 [ 17385 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_9/test_01666/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5932: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000388c391e 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6929: DB::StorageReplicatedMergeTree::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038b36406 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:22.080956 [ 16354 ] {c4237604-7e84-456b-92e5-1e29d28fa016} executeQuery: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37678) (comment: 00111_shard_external_sort_distributed.sql) (query 5, line 8) (in query: SET max_execution_time = 300;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:22.092480 [ 16354 ] {} TCPHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:22.431002 [ 19499 ] {589271d3-59cf-4617-8f81-2e7e6846cca6} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(argMax, String, UInt64) to AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) is not supported: While processing _CAST(arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)]) AS t_tmp_alter7682783365053747436, 'AggregateFunction(argMax, Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2), UInt64)') AS t: default expression and column type are incompatible. (CANNOT_CONVERT_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37662) (comment: 01258_wrong_cast_filimonov.sql) (query 1, line 1) (in query: CREATE TABLE x (`id` UInt64, `t` AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) DEFAULT arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)])) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 21847, min_bytes_for_wide_part = 556579203, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 472004640, compact_parts_max_bytes_to_buffer = 16951060, compact_parts_max_granules_to_buffer = 37, compact_parts_merge_max_bytes_to_prefetch_part = 23077813, merge_max_block_size = 20476, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 187341886, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1970091015, index_granularity_bytes = 30965437, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 56, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 63404, primary_key_compress_block_size = 24413, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000002c373421 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c366e23 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c31f2c1 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c31a528 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c319085 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000301da0a9 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000301d83b1 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031c600f2 12. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031c8ab73 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c6681a 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c62015 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031c40935 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031bbaca6 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031bf3072 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031bf43af 19. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edf1c 20. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:21:22.439643 [ 19499 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(argMax, String, UInt64) to AggregateFunction(argMax, Enum8('' = -1, 'Male' = 1, 'Female' = 2), UInt64) is not supported: While processing _CAST(arrayReduce('argMaxState', ['cast(-1, \'Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2)'], [toUInt64(0)]) AS t_tmp_alter7682783365053747436, 'AggregateFunction(argMax, Enum8(\'\' = -1, \'Male\' = 1, \'Female\' = 2), UInt64)') AS t: default expression and column type are incompatible. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x000000002c373421 5. DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c366e23 6. DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x000000002c31f2c1 7. DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002c31a528 8. DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x000000002c319085 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x00000000301da0a9 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:330: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x00000000301d83b1 11. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:697: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031c600f2 12. ./src/Interpreters/ActionsMatcher.h:178: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x0000000031c8ab73 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1366: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c6681a 14. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:756: DB::ActionsMatcher::visit(std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000031c62015 15. ./src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000031c40935 16. ./src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000031bbaca6 17. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000031bf3072 18. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000031bf43af 19. ./build_docker/./src/Storages/ColumnsDescription.cpp:1018: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x00000000382edf1c 20. ./build_docker/./src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000382ef313 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ca2e1 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 23. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 24. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:21:23.148855 [ 19619 ] {65fb8b7e-1cd3-40cf-af3b-fbea0d5b47a1} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37688) (comment: 02497_having_without_actual_aggregation_bug.sql) (query 4, line 7) (in query: select queryID() as t from numbers(10) with totals having t = initialQueryID();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x00000000305550ec 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:21:23.156866 [ 19619 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x00000000305550ec 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:21:23.997068 [ 19619 ] {62998a3b-b699-4927-a791-fb220a98bbd5} executeQuery: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37688) (comment: 02497_having_without_actual_aggregation_bug.sql) (query 5, line 8) (in query: select count() from (select queryID() as t from remote('127.0.0.{1..3}', numbers(10)) with totals having t = initialQueryID()) settings prefer_localhost_replica = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x00000000305550ec 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5354: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7c72 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:21:24.008480 [ 19619 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS, ROLLUP, CUBE or GROUPING SETS are not supported without aggregation. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:366: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x00000000305550ec 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5354: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7c72 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:21:24.729285 [ 18391 ] {ae10cd1d-8040-4a1c-ba03-cc415d1d0ed0} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(nan, 3.14, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37692) (comment: 01854_s2_cap_union.sql) (query 4, line 9) (in query: select s2CapUnion(nan, 3.14, 1157339245694594829, 3.14);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008c45817 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a437652 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:21:24.736741 [ 18391 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(nan, 3.14, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008c45817 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a437652 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:21:24.804394 [ 16355 ] {d4cb9411-5146-4ffd-8bdd-a77c07df8250} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37752) (comment: 02493_inconsistent_hex_and_binary_number.expect) (query 1, line 1) (in query: select 0b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:24.816647 [ 16355 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:25.773514 [ 16355 ] {201906ac-e29c-416c-bd97-ff586e5f4a04} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37774) (comment: 02493_inconsistent_hex_and_binary_number.expect) (query 1, line 1) (in query: select 0b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:25.782752 [ 5803 ] {b2ad2bac-4bbb-4a61-9c14-28720fc0fe20} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37748) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (query 1, line 1) (in query: select * from format(JSONEachRow, 'a Tuple(b UInt32)', '{"a" : {"b" : 1, "b" : 2}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x000000002f7fed1e 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x000000002f7f5fb7 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7e1726 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 23. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:21:25.792967 [ 16355 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:25.793341 [ 5803 ] {} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x000000002f7fed1e 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x000000002f7f5fb7 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7e1726 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 23. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:21:25.818938 [ 18391 ] {b15700fa-be0e-4462-84b8-fec2a110b40d} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37692) (comment: 01854_s2_cap_union.sql) (query 5, line 10) (in query: select s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4357b8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:21:25.825994 [ 18391 ] {} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4357b8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:21:25.904844 [ 18391 ] {2170351d-03a3-4317-8af3-eb18cfe266a4} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(1157339245694594829, 3.14, nan, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37692) (comment: 01854_s2_cap_union.sql) (query 6, line 11) (in query: select s2CapUnion(1157339245694594829, 3.14, nan, 3.14);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008c45817 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a437652 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:21:25.906074 [ 5803 ] {a3a2c66b-4046-4668-a3a3-b072105c6f95} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37748) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (query 2, line 2) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : 2}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x000000002f7fed1e 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x000000002f7f5fb7 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7e1726 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 23. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:21:25.912004 [ 18391 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(1157339245694594829, 3.14, nan, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x0000000008c45817 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001a437652 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:21:25.914275 [ 5803 ] {} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x000000002f7fed1e 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x000000002f7f5fb7 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7e1726 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 23. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:21:25.956111 [ 5803 ] {b2538452-920a-47c8-a480-c658e7d5b352} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37748) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (query 3, line 3) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : 2, "b" : 3}, "c" : 42}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x000000002f7fed1e 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x000000002f7f5fb7 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7e1726 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 23. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:21:25.964161 [ 5803 ] {} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x000000002f7fed1e 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x000000002f7f5fb7 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7e1726 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 23. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:21:25.974658 [ 18391 ] {e3e5b197-aa9a-4564-9582-1606c4045889} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37692) (comment: 01854_s2_cap_union.sql) (query 7, line 12) (in query: select s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4357b8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:21:25.983394 [ 18391 ] {} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a4357b8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:21:26.395610 [ 5803 ] {faac8a9d-6949-4457-8a7f-b89fa7f85812} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37748) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (query 6, line 6) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : "Hello"}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x000000002f7fed1e 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x000000002f7f5fb7 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7e1726 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 23. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:21:26.402747 [ 5803 ] {} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x000000002f7fed1e 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x000000002f7f5fb7 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7e1726 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 23. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:21:26.406833 [ 4170 ] {26e2351c-4bd5-4ea6-accf-63527e80c774} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=872). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57920) (comment: 00094_union_race_conditions_5.sh) (query 56, line 56) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:21:26.407568 [ 16354 ] {74709103-e52c-4833-b3b2-5d1c92ede43d} PushingToViews: Failed to push block to view test_9.mv_table (7ed412e9-6c9a-41b7-a7ad-9c949b5ebce4), ReplicatedMergeTree (table test_9.`.inner_id.7ed412e9-6c9a-41b7-a7ad-9c949b5ebce4` (df8e3db0-cb57-4c1c-8d4f-90a598c43e6c)) does not support transactions 2025.11.13 09:21:26.465758 [ 4170 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=872). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:21:26.517049 [ 5803 ] {486e656a-cc73-4b53-8da1-0db8b2152263} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37748) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (query 8, line 8) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : {"c" : "Hello"}}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x000000002f7fed1e 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x000000002f7f5fb7 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7e1726 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 23. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:21:26.525919 [ 5803 ] {} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:391: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const::'lambda'()::operator()() const @ 0x000000002f7fed1e 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:90: void DB::SerializationTuple::deserializeTupleJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)>(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda0'(DB::IColumn&, unsigned long)&&) const @ 0x000000002f7f5fb7 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:524: DB::SerializationTuple::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7e1726 7. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 8. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 10. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 11. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 22. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 23. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 2025.11.13 09:21:26.662745 [ 18391 ] {2ebd3cc6-4b71-483e-8c1c-a1129d919724} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37782) (comment: 02493_inconsistent_hex_and_binary_number.expect) (query 1, line 1) (in query: select 0b ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:26.677047 [ 18391 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0b` in scope SELECT `0b`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:27.554802 [ 16354 ] {74709103-e52c-4833-b3b2-5d1c92ede43d} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_9.`.inner_id.7ed412e9-6c9a-41b7-a7ad-9c949b5ebce4` (df8e3db0-cb57-4c1c-8d4f-90a598c43e6c)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37766) (comment: 03167_transactions_are_really_disabled.sql) (query 7, line 10) (in query: INSERT INTO null_table VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:328: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000032aca60d 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:376: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003bd5f11d 7. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd699ce 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000032ad1b23 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ada2a3 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000032adffb3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:21:27.562564 [ 16354 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_9.`.inner_id.7ed412e9-6c9a-41b7-a7ad-9c949b5ebce4` (df8e3db0-cb57-4c1c-8d4f-90a598c43e6c)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000329b265b 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:328: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000032aca60d 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:376: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003bd5f11d 7. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd699ce 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000032ad1b23 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ada2a3 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000032adffb3 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:21:27.674846 [ 16200 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 755.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:27.675817 [ 16200 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 755.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:27.694628 [ 5639 ] {c4402d07-815d-468d-9c5a-a1f23c33caed} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37820) (comment: 02493_inconsistent_hex_and_binary_number.expect) (query 1, line 1) (in query: select 0x), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:27.700636 [ 3735 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_75_13} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 752.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_75_75_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 77): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:27.702493 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_75_13}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 752.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_75_75_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 77): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:27.708745 [ 5639 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:27.738500 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 15 entries up to offset 1454: Code: 241. DB::Exception: (total) memory limit exceeded: would use 756.75 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:28.627411 [ 10170 ] {c88d3be6-251a-4506-bf1c-44e2a8a7d3e7} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37870) (comment: 02493_inconsistent_hex_and_binary_number.expect) (query 1, line 1) (in query: select 0x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:28.711349 [ 10170 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:29.008838 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_100_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 752.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:29.026418 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_100_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 752.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:29.628179 [ 10170 ] {17b3a1f7-50e9-4453-8022-fc589550c447} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37888) (comment: 02493_inconsistent_hex_and_binary_number.expect) (query 1, line 1) (in query: select 0x ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:29.641353 [ 10170 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `0x` in scope SELECT `0x`. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:21:30.067735 [ 5803 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000032f735f9 5. ./build_docker/./src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f73323 6. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:632: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003042bb2a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3876: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030417e3b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 32. ? @ 0x00007fa1506b4850 2025.11.13 09:21:30.891803 [ 17376 ] {b72b1a9e-68ae-47ab-bb92-bb59558d1bbc} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58216) (comment: 02918_join_pm_lc_crash.sql) (query 2, line 4) (in query: SET enable_analyzer = 0, join_use_nulls = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:30.902548 [ 17376 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:31.910092 [ 3737 ] {4b883210-87cf-4b20-bfcb-c29c1d17ba07::202511_1_19_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:31.912076 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4b883210-87cf-4b20-bfcb-c29c1d17ba07::202511_1_19_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:33.540083 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_100_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 621.63 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:33.542058 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_100_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 621.63 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:34.182651 [ 17390 ] {274beeaf-0eba-4c91-9b9d-3e179eac4ae0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58200) (comment: 00094_union_race_conditions_5.sh) (query 15, line 15) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:21:34.269229 [ 17390 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:34.412908 [ 18722 ] {feda5bf4-001a-4e54-aa87-35d1414aeab0} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1046.212088 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58220) (comment: 03223_analyzer_with_cube_fuzz.sql) (query 8, line 12) (in query: SELECT 1 * 1000.0001, (count(1.) = -2147483647) AND (count(a) = 1.1920928955078125e-7) AND (count(val) = 1048577) AND (sum(val) = ((NULL * 1048576) / -9223372036854775807)) AND (sum(a) = ((9223372036854775806 * 10000000000.) / 1048575)) FROM ( SELECT a, val FROM t1 FULL OUTER JOIN t2 ON (t1.a = t2.key) OR (1 * inf) OR (t1.b = t2.key) ) GROUP BY '65537' WITH CUBE FORMAT Null SETTINGS max_block_size = 100, join_use_nulls = 1, max_execution_time = 1., max_result_rows = 0, max_result_bytes = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:21:34.458170 [ 18722 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1046.212088 ms, maximum: 1000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:34.960022 [ 17376 ] {55454ad3-2722-49da-aee3-79efe36f89be} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58234) (comment: 01049_join_low_card_bug_long.gen.sql) (query 19, line 25) (in query: -- { echoOn } SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:34.977564 [ 17376 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:35.771248 [ 16054 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 636.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:35.772291 [ 16054 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 636.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:35.821692 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_186_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 637.31 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9467): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:35.823708 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_186_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 637.31 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9467): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:37.473566 [ 5803 ] {bbb3fd57-45c6-4969-aec6-18b1d06684c7} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58238) (comment: 03047_on_fly_mutations_projections.sql) (query 10, line 21) (in query: SELECT sum(v) FROM t_update_projections SETTINGS force_optimize_projection = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c563c 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:21:37.480532 [ 5803 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c563c 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:21:37.739546 [ 17390 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:37.835223 [ 17376 ] {7b435836-9d47-40da-9536-69d2ebaffd34} executeQuery: Code: 179. DB::Exception: Multiple expressions 2 AS value and 1 AS value for alias value. In scope SELECT 1 AS value, 2 AS value. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58280) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 9, line 17) (in query: SELECT 1 AS value, 2 AS value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:37.842287 [ 17376 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions 2 AS value and 1 AS value for alias value. In scope SELECT 1 AS value, 2 AS value. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:37.902273 [ 17376 ] {4ef2002f-0054-4fec-8754-f36d615fa313} executeQuery: Code: 179. DB::Exception: Multiple expressions 2 AS value and _CAST(2, 'UInt16') for alias value. In scope SELECT 1 + 1 AS value, 2 AS value. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58280) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 10, line 18) (in query: SELECT plus(1, 1) AS value, 2 AS value;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:37.911101 [ 17376 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions 2 AS value and _CAST(2, 'UInt16') for alias value. In scope SELECT 1 + 1 AS value, 2 AS value. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:38.199792 [ 17376 ] {8d4abe59-9ecc-425d-af24-d3a55c863d92} executeQuery: Code: 179. DB::Exception: Multiple expressions 1 AS subquery and (SELECT 1) AS subquery for alias subquery. In scope SELECT (SELECT 1) AS subquery, 1 AS subquery. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58280) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 11, line 19) (in query: SELECT (SELECT 1) AS subquery, 1 AS subquery;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:38.307058 [ 17376 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions 1 AS subquery and (SELECT 1) AS subquery for alias subquery. In scope SELECT (SELECT 1) AS subquery, 1 AS subquery. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:38.659665 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_101_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 632.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:38.662021 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_101_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 632.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:38.670586 [ 5803 ] {57190ae9-ad56-47df-b433-71238b7655b9} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58306) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:38.748924 [ 5803 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.126207 [ 5803 ] {058106fb-e451-405f-b0d1-51ea13e5ce19} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58316) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.164045 [ 5803 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.504829 [ 19606 ] {17866633-ec09-4078-9e48-067f03df9a91} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58328) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.541081 [ 19606 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.616190 [ 3729 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_186_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 615.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column value7): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_184_184_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1809): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:39.618173 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_186_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 615.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column value7): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_184_184_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1809): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:39.666279 [ 17376 ] {4b5c4b95-3f2d-419c-81dd-28b2ed7360a8} executeQuery: Code: 179. DB::Exception: Multiple expressions x -> (x + 2) AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda, (x -> (x + 2)) AS lambda SELECT lambda(1). (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58280) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 12, line 20) (in query: WITH x -> x + 1 AS lambda, x -> x + 2 AS lambda SELECT lambda(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5782: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030401655 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.674468 [ 17376 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions x -> (x + 2) AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda, (x -> (x + 2)) AS lambda SELECT lambda(1). (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5782: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030401655 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.817343 [ 5803 ] {997e06f1-ae45-4f41-bd90-f99b34495334} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58340) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.857953 [ 17376 ] {d91dd52f-89e9-4cae-9495-373170c7c777} executeQuery: Code: 179. DB::Exception: Multiple expressions (SELECT 1) AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda SELECT (SELECT 1) AS lambda. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58280) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 13, line 21) (in query: WITH x -> x + 1 AS lambda SELECT (SELECT 1) AS lambda;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5782: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030401655 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.870689 [ 17376 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions (SELECT 1) AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda SELECT (SELECT 1) AS lambda. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5782: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030401655 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.899675 [ 5803 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.919096 [ 17376 ] {a7ac51dd-02e5-4ffb-ba90-943ee6d37354} executeQuery: Code: 179. DB::Exception: Multiple expressions 1 AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda SELECT 1 AS lambda. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58280) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 14, line 22) (in query: WITH x -> x + 1 AS lambda SELECT 1 AS lambda;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5782: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030401655 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:39.926579 [ 17376 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions 1 AS lambda and x -> (x + 1) AS lambda for alias lambda. In scope WITH x -> (x + 1) AS lambda SELECT 1 AS lambda. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5782: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000030401655 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.004761 [ 17376 ] {5f637d67-c7b0-4811-8e32-3401f9a9400d} executeQuery: Code: 179. DB::Exception: Multiple expressions test_0x35kg04.test_table.value and test_0x35kg04.test_table.id for alias value. In scope SELECT id AS value, value AS value FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58280) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 15, line 23) (in query: SELECT id AS value, value AS value FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.015199 [ 17376 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions test_0x35kg04.test_table.value and test_0x35kg04.test_table.id for alias value. In scope SELECT id AS value, value AS value FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.056547 [ 17376 ] {66878d6d-4988-4e98-a6e1-8a88d7fedb8a} executeQuery: Code: 179. DB::Exception: Multiple expressions test_0x35kg04.test_table.value and test_0x35kg04.test_table.id for alias value_1. In scope SELECT id AS value_1, value AS value_1 FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58280) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 16, line 24) (in query: SELECT id AS value_1, value AS value_1 FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.063599 [ 17376 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions test_0x35kg04.test_table.value and test_0x35kg04.test_table.id for alias value_1. In scope SELECT id AS value_1, value AS value_1 FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.086692 [ 16198 ] {757f6830-1eb1-49e8-97d3-1218aa81fc1f} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58346) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.098392 [ 16198 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.113071 [ 17376 ] {313aea46-d03b-4fcf-b1ed-1e765da89999} executeQuery: Code: 179. DB::Exception: Multiple expressions id + 1 AS value and test_0x35kg04.test_table.id for alias value. In scope SELECT id AS value, id + 1 AS value FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58280) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (query 17, line 25) (in query: SELECT id AS value, (id + 1) AS value FROM test_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.216402 [ 17376 ] {} TCPHandler: Code: 179. DB::Exception: Multiple expressions id + 1 AS value and test_0x35kg04.test_table.id for alias value. In scope SELECT id AS value, id + 1 AS value FROM test_table. (MULTIPLE_EXPRESSIONS_FOR_ALIAS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&, String&&) @ 0x00000000304cdcbf 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5765: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003040113f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.216520 [ 18403 ] {3a0da3d5-19a7-4c36-a72e-8926b89503b9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39750) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_01516_test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.226833 [ 18403 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.235705 [ 5803 ] {c2cf0018-66b1-4e42-9ac9-aeef371458d7} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58352) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.253691 [ 5803 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.369465 [ 16198 ] {d5f40fa3-b9cb-4acc-b6e8-4143a3caca9c} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58364) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.389929 [ 16198 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.440586 [ 16132 ] {e8c7d776-54b7-4232-a941-367780ba079b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40420) (comment: 02344_analyzer_multiple_aliases_for_expression.sql) (in query: DROP DATABASE IF EXISTS test_0x35kg04 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.449109 [ 16132 ] {e8c7d776-54b7-4232-a941-367780ba079b} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:40.514955 [ 5803 ] {560b9dd7-5a85-4e40-826a-29d0ee6396ee} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58370) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.538803 [ 5803 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.807495 [ 18824 ] {6211180c-aba6-4c86-94e8-8b0dab633d97} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44304) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.826914 [ 18824 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.970478 [ 15982 ] {55b2ebf3-ffd5-4260-bb24-e6bd005edc59} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40450) (comment: 01881_aggregate_functions_versioning.sql) (in query: DROP DATABASE IF EXISTS test_d3g8vf9w SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:21:40.978264 [ 15982 ] {55b2ebf3-ffd5-4260-bb24-e6bd005edc59} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:41.008281 [ 16446 ] {1d4ac190-1b20-4455-ba38-568cbf7cf46e} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44310) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:41.024273 [ 16446 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:41.097921 [ 16354 ] {35f34e5f-7677-4d94-8418-21950e8287b6} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 615.20 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column query): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_83_97_2/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 6794): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37874) (comment: 02477_s3_request_throttler.sh) (query 9, line 16) (in query: SELECT ProfileEvents['S3CreateMultipartUpload'] == 1, ProfileEvents['S3UploadPart'] == 1, ProfileEvents['S3CompleteMultipartUpload'] == 1 FROM system.query_log WHERE query LIKE '%request-throttler.csv%' AND type = 'QueryFinish' AND current_database = currentDatabase() ORDER BY query_start_time DESC LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 2025.11.13 09:21:41.215734 [ 15982 ] {99daaa2e-68ae-412d-af12-4438b4eb310b} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44330) (comment: 02490_benchmark_max_consecutive_errors.sh) (in query: select throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:21:41.230430 [ 15982 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001aa6d7c3 5. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 9. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 11. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:41.316802 [ 16354 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 615.20 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column query): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_83_97_2/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 6794): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:42.524420 [ 16054 ] {94a8f4c4-8f16-4e04-b438-d61de82fcabd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: String: In scope SELECT space('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58296) (comment: 02752_space_function.sql) (query 17, line 19) (in query: SELECT space('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a621e8d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:21:42.550372 [ 16054 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: String: In scope SELECT space('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a621e8d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:21:42.588506 [ 16054 ] {cf855c12-a666-4893-a1db-b9938396b286} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: Array(String): In scope SELECT space(['abc']). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58296) (comment: 02752_space_function.sql) (query 18, line 20) (in query: SELECT space(['abc']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a621e8d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:21:42.598733 [ 16054 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: Array(String): In scope SELECT space(['abc']). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a621e8d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:21:42.639027 [ 16054 ] {d181db78-980c-4198-b546-ee356d42b207} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: String: In scope SELECT space('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58296) (comment: 02752_space_function.sql) (query 19, line 21) (in query: SELECT space(('abc'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a621e8d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:21:42.646045 [ 16054 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'n' to function 'space'. Expected: Integer, got: String: In scope SELECT space('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::(anonymous namespace)::FunctionSpace::getReturnTypeImpl(std::vector> const&) const @ 0x000000001a621e8d 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:21:42.915114 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_102_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 686.66 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:42.917725 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_102_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 686.66 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:43.992212 [ 16054 ] {f7bd15ec-674e-46ac-ad14-bd7e91ea6636} executeQuery: Code: 131. DB::Exception: Too many times to repeat (18011680617995229494), maximum is: 1000000: In scope SELECT space(CAST('30303030303030303030303030303030', 'UInt64')). (TOO_LARGE_STRING_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58296) (comment: 02752_space_function.sql) (query 20, line 22) (in query: SELECT space(30303030303030303030303030303030::UInt64);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b2043ed 4. DB::(anonymous namespace)::FunctionSpace::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a620948 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:21:44.000949 [ 16054 ] {} TCPHandler: Code: 131. DB::Exception: Too many times to repeat (18011680617995229494), maximum is: 1000000: In scope SELECT space(CAST('30303030303030303030303030303030', 'UInt64')). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b2043ed 4. DB::(anonymous namespace)::FunctionSpace::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a620948 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:21:44.944582 [ 18771 ] {6add2630-0eac-4ead-afb0-e436b2dc119c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44428) (comment: 02553_type_json_attach_partition.sql) (query 1, line 1) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:44.953061 [ 18771 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:45.250039 [ 15982 ] {70e0cbdb-6df6-455a-b62a-9dc434e409db} executeQuery: Code: 57. DB::Exception: Table test_7.test_local already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44442) (comment: 02695_logical_optimizer_alias_bug.sql) (query 1, line 1) (in query: CREATE TABLE test_local (`id` UInt32, `path` LowCardinality(String)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 38141, min_bytes_for_wide_part = 725656363, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 45866360, compact_parts_max_granules_to_buffer = 63, compact_parts_merge_max_bytes_to_prefetch_part = 22782812, merge_max_block_size = 1529, old_parts_lifetime = 280., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9801766451, index_granularity_bytes = 5399437, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 35110, primary_key_compress_block_size = 92293, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:21:45.268299 [ 15982 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.test_local already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:21:45.826290 [ 18824 ] {3c78019c-c43d-41ba-b3f6-81dc6c4a1701} executeQuery: Code: 141. DB::Exception: Illegal SAMPLE: table test_gdpotuu0.numbers1 (5468c1fa-64db-49e1-9027-5643abf73f8d) doesn't support sampling: Child table: test_gdpotuu0.numbers1 (5468c1fa-64db-49e1-9027-5643abf73f8d). (SAMPLING_NOT_SUPPORTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44410) (comment: 00578_merge_table_sampling.sql) (query 5, line 7) (in query: SELECT * FROM merge(currentDatabase(), '^numbers\\d+$') SAMPLE 0.1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageMerge.cpp:652: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x00000000387c3b49 5. ./build_docker/./src/Storages/StorageMerge.cpp:588: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x00000000387b1348 6. ./build_docker/./src/Storages/StorageMerge.cpp:1638: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x00000000387ed560 7. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003c4c99c7 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:49: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c4c9208 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c37a6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:45.836868 [ 18824 ] {} TCPHandler: Code: 141. DB::Exception: Illegal SAMPLE: table test_gdpotuu0.numbers1 (5468c1fa-64db-49e1-9027-5643abf73f8d) doesn't support sampling: Child table: test_gdpotuu0.numbers1 (5468c1fa-64db-49e1-9027-5643abf73f8d). (SAMPLING_NOT_SUPPORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageMerge.cpp:652: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x00000000387c3b49 5. ./build_docker/./src/Storages/StorageMerge.cpp:588: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x00000000387b1348 6. ./build_docker/./src/Storages/StorageMerge.cpp:1638: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x00000000387ed560 7. ./src/Processors/QueryPlan/SourceStepWithFilter.h:39: DB::SourceStepWithFilterBase::applyFilters() @ 0x000000003c4c99c7 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:49: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000003c4c9208 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:125: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c37a6 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:21:46.210689 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_102_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 639.98 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:46.213232 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_102_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 639.98 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:46.321107 [ 17383 ] {1e4137f8-0112-4f25-850e-a87f0ebe43be} executeQuery: Code: 57. DB::Exception: Table test_7.test_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44482) (comment: 02517_executable_pool_bad_input_query.sql) (query 1, line 1) (in query: CREATE TABLE test_table (value String) ENGINE=ExecutablePool('nonexist.py', 'TabSeparated', (foobar));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:21:46.334568 [ 17383 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:21:47.841341 [ 17388 ] {d1bf8b77-af0d-4b6e-bf44-af189329a031} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02941_variant_type_2.sh) (in query: /* ddl_entry=query-0000000165 */ CREATE TABLE test_11.test UUID '9f57528b-fa32-4342-8b2d-d9560b79d50f' (`id` UInt64, `v` Variant(Array(UInt64), LowCardinality(String), String, Tuple(a UInt32, b UInt32), UInt64)) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 506383142, compact_parts_max_granules_to_buffer = 107, compact_parts_merge_max_bytes_to_prefetch_part = 30170523, merge_max_block_size = 1400, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 3105005408, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 56835, primary_key_compress_block_size = 45079, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:21:47.874743 [ 17388 ] {d1bf8b77-af0d-4b6e-bf44-af189329a031} executeQuery: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44522) (comment: 02941_variant_type_2.sh) (query 1, line 1) (in query: CREATE TABLE test (`id` UInt64, `v` Variant(String, UInt64, LowCardinality(String), Tuple(a UInt32, b UInt32), Array(UInt64))) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity_bytes = 10485760, index_granularity = 8192, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 506383142, compact_parts_max_granules_to_buffer = 107, compact_parts_merge_max_bytes_to_prefetch_part = 30170523, merge_max_block_size = 1400, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 3105005408, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 56835, primary_key_compress_block_size = 45079, use_primary_key_cache = true, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:21:47.893299 [ 17388 ] {} TCPHandler: Code: 57. DB::Exception: Table test_11.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:21:48.136226 [ 15982 ] {53b94518-eced-43ec-bb0d-1840e6db1f62} executeQuery: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 4, line 6) (in query: SELECT * FROM remote('[::1', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a12f1 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:48.147639 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a12f1 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:49.116047 [ 15982 ] {06986288-158a-45f7-9cec-e37477210482} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 5, line 7) (in query: SELECT * FROM remote('::1]', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:49.129910 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:49.181057 [ 15982 ] {8671edf5-50e9-4b94-ac91-69aba44a76e4} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 6, line 8) (in query: SELECT * FROM remote('::1', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:49.188885 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:49.515229 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 2264 entries up to offset 224854: Code: 241. DB::Exception: (total) memory limit exceeded: would use 688.07 MiB (attempt to allocate chunk of 4.18 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:49.644443 [ 3726 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_103_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 684.96 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:49.656586 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_103_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 684.96 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:50.169878 [ 15982 ] {20659cf9-078a-4749-bcc1-fa5bd261dcaf} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 7, line 10) (in query: SELECT * FROM remote('[::1][::1]', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a2055 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:50.177692 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a2055 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:50.308594 [ 15982 ] {14a526d0-dd5d-4ab1-b2e1-72f85685f788} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 8, line 11) (in query: SELECT * FROM remote('[::1][::1', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a2055 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:50.315894 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a2055 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:50.363400 [ 15982 ] {55f892a5-65d4-4a18-a353-4038565becfe} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 9, line 12) (in query: SELECT * FROM remote('[::1]::1]', system.one) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:50.371297 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:51.184424 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_103_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 712.74 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:51.188946 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_103_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 712.74 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:51.911198 [ 15982 ] {1e2b56a6-c7e9-4ebe-a809-0004798aef36} executeQuery: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 12, line 17) (in query: SELECT * FROM remote('[::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a12f1 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:51.918906 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal address passed to function parseAddress: the address begins with opening square bracket, but no closing square bracket found. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Common/parseAddress.cpp:28: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a12f1 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:51.962852 [ 15982 ] {11cd36f7-0043-40e7-925d-625559640790} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 13, line 18) (in query: SELECT * FROM remote('::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:51.970718 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:52.119910 [ 15982 ] {beca7a3b-36a8-45f5-8393-8e392f3a0ac1} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 14, line 19) (in query: SELECT * FROM remote('::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:52.127662 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:52.234883 [ 15982 ] {5c943fd4-a6a9-4352-92a6-10a9d595f24a} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 15, line 21) (in query: SELECT * FROM remote('[::1][::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a2055 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:52.242906 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a2055 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:52.285616 [ 15982 ] {a7144717-e1a2-4e6a-bd1c-09177a89e587} executeQuery: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 16, line 22) (in query: SELECT * FROM remote('[::1][::1') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a2055 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:52.293267 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port prefix passed to function parseAddress: [::1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:39: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a2055 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:52.336735 [ 15982 ] {a8e0b50c-031d-490f-b750-3b5a5ab965a0} executeQuery: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44458) (comment: 01880_remote_ipv6.sql) (query 17, line 23) (in query: SELECT * FROM remote('[::1]::1]') FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:52.344009 [ 15982 ] {} TCPHandler: Code: 36. DB::Exception: Illegal port passed to function parseAddress: :1]. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x0000000008c1abca 4. ./build_docker/./src/Common/parseAddress.cpp:48: DB::parseAddress(String const&, unsigned short) @ 0x00000000267a1813 5. ./build_docker/./src/Interpreters/Cluster.cpp:153: DB::Cluster::Address::Address(DB::DatabaseReplicaInfo const&, DB::ClusterConnectionParameters const&, unsigned int, unsigned int) @ 0x00000000317118d9 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Cluster::Cluster(DB::Settings const&, std::vector>, std::allocator>>> const&, DB::ClusterConnectionParameters const&) @ 0x000000003172b333 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000266e7440 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:21:52.656339 [ 3729 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_66_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 712.73 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 16. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000037876e4e 18. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 19. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 20. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375d90df 22. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 23. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 24. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 26. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 27. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 28. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:52.658382 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_66_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 712.73 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 16. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000037876e4e 18. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 19. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 20. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375d90df 22. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 23. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 24. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 26. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 27. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 28. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:53.040708 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 693.04 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:53.041912 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 693.04 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:53.302673 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_103_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 693.11 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:53.304523 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_103_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 693.11 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:55.230530 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 723.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:55.232344 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 723.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:55.562650 [ 6072 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:55.563728 [ 6072 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:21:56.564873 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 643.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:56.565919 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 643.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:56.661366 [ 16203 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 610.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:56.764963 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 662.72 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:56.772128 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 662.72 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:57.598898 [ 16233 ] {4d7e58af-5245-4e8a-bdd4-53016c419869} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 0.00 B (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56460) (comment: 02941_variant_type_2.sh) (query 6, line 6) (in query: select count() from test where isNotNull(v.UInt64);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:21:57.619951 [ 16233 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 0.00 B (attempt to allocate chunk of 0.00 B), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:57.674118 [ 16889 ] {5915b402-cb39-4302-967a-c498d3ab1c23} executeQuery: Code: 43. DB::Exception: First argument for function tupleNames must be a tuple: In scope SELECT tupleNames(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56482) (comment: 02890_named_tuple_functions.sql) (query 14, line 20) (in query: select tupleNames(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::TupleNamesOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ae92494 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:21:57.682396 [ 16889 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleNames must be a tuple: In scope SELECT tupleNames(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::(anonymous namespace)::TupleNamesOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ae92494 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:21:57.904794 [ 16398 ] {1c79bf2e-b3c4-4fd3-b10c-4d91288f3e95} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 165041.057255 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41442) (comment: 01037_polygon_dicts_correctness_fast.sh) (query 3, line 15) (in query: select 'dictGet', 'dict_array' as dict_name, tuple(x, y) as key, dictGet(dict_name, 'value', key) from points order by x, y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x0000000031b8674d 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f732ea 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:21:58.006191 [ 16398 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 165041.057255 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x0000000031b8674d 4. ./build_docker/./src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000032f732ea 5. ./build_docker/./src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f74883 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:58.982953 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 690.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:58.985055 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 690.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:21:59.186949 [ 6078 ] {29e6faba-c74f-4f56-be48-1c9790957f02} executeQuery: Code: 48. DB::Exception: Method optimize is not supported by storage Memory. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56578) (comment: 02941_variant_type_2.sh) (query 1, line 1) (in query: optimize table test final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000038359ad0 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033957419 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 7. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:59.215000 [ 6078 ] {} TCPHandler: Code: 48. DB::Exception: Method optimize is not supported by storage Memory. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000038359ad0 4. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000033957419 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 7. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:21:59.353675 [ 16203 ] {8588ae22-e445-4afb-b767-3f633e233b81} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path. You can specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56584) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_zcemr8gu_test1.`tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/StorageFile.cpp:962: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000003850032b 5. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 6. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 7. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 8. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 13. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:161: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8eb0de 14. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 15. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 16. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 17. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:21:59.365698 [ 16203 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path. You can specify table structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/StorageFile.cpp:962: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x000000003850032b 5. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 6. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 7. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 8. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 11. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 12. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 13. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:161: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8eb0de 14. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 15. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 16. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 17. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:22:00.182206 [ 16233 ] {0c0c709f-f9f5-469b-af9f-6dba80ae5c57} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1, line 1) (in query: SELECT BIT_AND([NULL], [NULL], [NULL]);) 2025.11.13 09:22:00.282071 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:00.483850 [ 16233 ] {8dd28a08-6ebe-4191-a1a6-a43306cfba91} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 2, line 2) (in query: SELECT BIT_OR([NULL], [NULL], [NULL]);) 2025.11.13 09:22:00.531939 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:00.675114 [ 16233 ] {bceefda7-9e6c-478e-bc09-836c51a85468} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 3, line 3) (in query: SELECT BIT_XOR([NULL], [NULL], [NULL]);) 2025.11.13 09:22:00.688583 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:00.762361 [ 16233 ] {35ba7adc-9900-44c1-8a72-737c4f7f85f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 4, line 4) (in query: SELECT BLAKE3([NULL], [NULL], [NULL]);) 2025.11.13 09:22:00.775432 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:00.859475 [ 16233 ] {fcf6dd13-cc06-4f40-9758-9133813583b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 5, line 6) (in query: SELECT CHARACTER_LENGTH([NULL], [NULL], [NULL]);) 2025.11.13 09:22:00.943752 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:01.009548 [ 16233 ] {e17cf338-3c70-45dc-9372-4efad15220f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 6, line 7) (in query: SELECT CHAR_LENGTH([NULL], [NULL], [NULL]);) 2025.11.13 09:22:01.028231 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:01.061588 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 587.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:01.062666 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 587.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:01.069595 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 612.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:01.072108 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 612.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:01.118420 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 571.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:01.119578 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 571.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:01.185115 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:01.186023 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:01.233836 [ 16233 ] {57874ff7-5a55-444f-81ea-db186c388fb8} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 7, line 8) (in query: SELECT COVAR_POP([NULL], [NULL], [NULL]);) 2025.11.13 09:22:01.247286 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:01.373952 [ 16233 ] {297e14ba-c00c-4738-bd75-e21be0f6b57e} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 8, line 9) (in query: SELECT COVAR_SAMP([NULL], [NULL], [NULL]);) 2025.11.13 09:22:01.385368 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:01.541496 [ 16233 ] {0998b9cf-c3a2-42f1-8820-2be71902782a} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 9, line 10) (in query: SELECT CRC32([NULL], [NULL], [NULL]);) 2025.11.13 09:22:01.590851 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:01.698399 [ 16233 ] {f31d0d17-7a7d-4419-94fd-6173a0e93777} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 10, line 11) (in query: SELECT CRC32IEEE([NULL], [NULL], [NULL]);) 2025.11.13 09:22:01.710888 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:01.781018 [ 16233 ] {af7eff96-b8bc-4c17-9a7d-6f3781b85a4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 11, line 12) (in query: SELECT CRC64([NULL], [NULL], [NULL]);) 2025.11.13 09:22:01.815394 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:01.889317 [ 16233 ] {406f62e3-356d-417f-adc3-c0ac78554ff3} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 12, line 13) (in query: SELECT DATABASE([NULL], [NULL], [NULL]);) 2025.11.13 09:22:01.901510 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:01.954859 [ 16605 ] {4423a069-0617-48a6-925b-f3f4e2f44738} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 612.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38794) (comment: 02555_davengers_rename_chain.sh) (query 3, line 13) (in query: INSERT INTO wrong_metadata VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 31. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:373: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a3c209c 2025.11.13 09:22:02.034776 [ 16605 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 612.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 31. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:373: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a3c209c 2025.11.13 09:22:02.136605 [ 16233 ] {9a188aa1-da20-4bcb-b203-47375dc63a98} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT DATE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 13, line 14) (in query: SELECT DATE([NULL], [NULL], [NULL]);) 2025.11.13 09:22:02.156308 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT DATE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:02.256778 [ 16233 ] {ded9d48a-28a3-4ceb-be2c-8d5e9caf6ff5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 14, line 15) (in query: SELECT DATE_DIFF([NULL], [NULL], [NULL]);) 2025.11.13 09:22:02.274313 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:02.342140 [ 16233 ] {5b22c7f7-0a98-4d4c-b8f5-d7bd4efe5d2c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT DATE_FORMAT([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 15, line 16) (in query: SELECT DATE_FORMAT([NULL], [NULL], [NULL]);) 2025.11.13 09:22:02.431449 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT DATE_FORMAT([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:02.465617 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:02.467622 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:02.480887 [ 16233 ] {c700071c-9538-4c33-8d77-c5ed3127a37c} executeQuery: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT DATE_TRUNC([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 16, line 17) (in query: SELECT DATE_TRUNC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:02.562381 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT DATE_TRUNC([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:02.633246 [ 16233 ] {bb6312de-d5dc-412a-9961-d02b3994cfb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAY([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 17, line 18) (in query: SELECT DAY([NULL], [NULL], [NULL]);) 2025.11.13 09:22:02.650994 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAY([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:02.705351 [ 16233 ] {3d153a2a-adba-4f7f-9b70-479868805ca6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFMONTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 18, line 19) (in query: SELECT DAYOFMONTH([NULL], [NULL], [NULL]);) 2025.11.13 09:22:02.716265 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFMONTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:02.811009 [ 19621 ] {8190ff6f-3830-44fa-90d5-98455e67ec59} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38854) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_zcemr8gu_test1.`/tmp/tmp.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x000000002f8e91d8 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8ea91d 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:02.841645 [ 19621 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x000000002f8e91d8 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8ea91d 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:02.962716 [ 16233 ] {dda72521-947d-4368-8c54-8ad74cf60975} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFWEEK([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 19, line 20) (in query: SELECT DAYOFWEEK([NULL], [NULL], [NULL]);) 2025.11.13 09:22:02.977977 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFWEEK([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:03.188745 [ 16233 ] {60af668b-0e5f-4a9b-be19-b3dcb7924137} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFYEAR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 20, line 21) (in query: SELECT DAYOFYEAR([NULL], [NULL], [NULL]);) 2025.11.13 09:22:03.214225 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFYEAR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:03.263134 [ 16233 ] {8ea38d14-162d-47d8-8ce2-1f787ecda5ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 21, line 22) (in query: SELECT FORMAT_BYTES([NULL], [NULL], [NULL]);) 2025.11.13 09:22:03.277368 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:03.339141 [ 16233 ] {504b7397-0e6d-460a-b5a6-fa704c52f246} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 22, line 23) (in query: SELECT FQDN([NULL], [NULL], [NULL]);) 2025.11.13 09:22:03.353851 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:03.417589 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 538.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:03.418678 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 538.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:03.462592 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 537.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:03.464211 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 537.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:03.495320 [ 16233 ] {c9a44f5e-0802-48dd-8ef2-26a9295cef6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 23, line 24) (in query: SELECT FROM_BASE64([NULL], [NULL], [NULL]);) 2025.11.13 09:22:03.507546 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:03.675574 [ 16233 ] {9efd6063-661e-4a24-a3da-598059f49acc} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 24, line 25) (in query: SELECT FROM_DAYS([NULL], [NULL], [NULL]);) 2025.11.13 09:22:03.725618 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:03.783627 [ 16233 ] {ac2b9f6e-2a3d-4c0a-a891-17d1a92eb0be} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT FROM_UNIXTIME([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 25, line 26) (in query: SELECT FROM_UNIXTIME([NULL], [NULL], [NULL]);) 2025.11.13 09:22:03.794226 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT FROM_UNIXTIME([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:03.815602 [ 18149 ] {a6434788-6563-4932-b50e-4d7bb270e0b4} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38944) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_zcemr8gu_test1.`../*/tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x000000002f8e91d8 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8ea91d 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:03.826444 [ 18149 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x000000002f8e91d8 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8ea91d 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:03.851617 [ 16233 ] {886bee47-3ea6-409d-b9ee-f9cc6f79607b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT HOUR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 26, line 27) (in query: SELECT HOUR([NULL], [NULL], [NULL]);) 2025.11.13 09:22:03.865063 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT HOUR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:03.970722 [ 3727 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 583.29 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:03.972547 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 583.29 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:03.985120 [ 16233 ] {7d2308b7-6dc7-4335-b643-297094f01675} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 27, line 28) (in query: SELECT INET6_ATON([NULL], [NULL], [NULL]);) 2025.11.13 09:22:03.996032 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.065653 [ 16233 ] {16d61e5c-60b3-4257-99e6-e7c0c6841dca} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 28, line 29) (in query: SELECT INET6_NTOA([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.089523 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.146066 [ 16233 ] {4c026d57-136e-41a6-969a-20e16e4de09e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 29, line 30) (in query: SELECT INET_ATON([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.160040 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.219689 [ 16233 ] {87a45892-5a13-435d-86b2-b8f1875ecd1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 30, line 31) (in query: SELECT INET_NTOA([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.233420 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.293400 [ 16233 ] {ea4bc089-abc2-46a3-ac0e-adf7a2d1fa1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 31, line 32) (in query: SELECT IPv4CIDRToRange([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.297858 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 583.33 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:04.299659 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 583.33 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:04.307234 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.311665 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 583.33 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:04.366221 [ 16233 ] {834badb4-ef5f-43e7-8f32-13a99d463088} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 32, line 33) (in query: SELECT IPv4NumToString([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.378553 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.394220 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 583.33 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:04.436478 [ 16233 ] {7f3eeb02-071f-4a1b-8ee9-db8354ef0f22} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 33, line 34) (in query: SELECT IPv4NumToStringClassC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.449220 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.516086 [ 16233 ] {552f7b4c-4de1-48d5-9366-fe77bafef2c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 34, line 35) (in query: SELECT IPv4StringToNum([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.528959 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.619453 [ 3735 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_129_27} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 538.95 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:04.621581 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_129_27}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 538.95 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:04.656731 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 532.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:04.657787 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 532.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:04.691180 [ 16233 ] {70f5a408-2a10-4a43-be91-26d2c74a29b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 35, line 36) (in query: SELECT IPv4StringToNumOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.702761 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.703828 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 533.09 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:04.705738 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 533.09 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:04.773417 [ 16233 ] {1785f92e-cc07-40b5-ac8f-ed828a5b3a0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 36, line 37) (in query: SELECT IPv4StringToNumOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.797326 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.845205 [ 19621 ] {b13c0034-e00a-4253-ab82-1c200de297d5} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38984) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_zcemr8gu_test1.`../tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x000000002f8e91d8 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8ea91d 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:04.856022 [ 19621 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x000000002f8e91d8 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8ea91d 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:04.861304 [ 16233 ] {9fec6b08-cbc5-4e89-8a17-af3948e1e960} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 37, line 38) (in query: SELECT IPv4ToIPv6([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.873305 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:04.940314 [ 16233 ] {d19c4cbb-f8c4-4ace-9a24-1eb697ca3696} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 38, line 39) (in query: SELECT IPv6CIDRToRange([NULL], [NULL], [NULL]);) 2025.11.13 09:22:04.951360 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:05.022308 [ 16233 ] {596788da-9f34-485b-a09c-e2ce23d70c72} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 39, line 40) (in query: SELECT IPv6NumToString([NULL], [NULL], [NULL]);) 2025.11.13 09:22:05.035894 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:05.119667 [ 16233 ] {9f235278-83ab-4a90-83be-d4cd98fdc933} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 40, line 41) (in query: SELECT IPv6StringToNum([NULL], [NULL], [NULL]);) 2025.11.13 09:22:05.136126 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:05.210033 [ 16233 ] {f6b74e6a-dc52-4be6-a85a-6793b5741b9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 41, line 42) (in query: SELECT IPv6StringToNumOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:05.225436 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:05.290240 [ 16233 ] {478a6e5f-c6c7-41e7-b049-13fc8dd6b000} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 42, line 43) (in query: SELECT IPv6StringToNumOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:22:05.302650 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:05.429617 [ 16233 ] {b52439c6-c840-4c73-9525-91c46f497c40} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 43, line 44) (in query: SELECT JSONAllPaths([NULL], [NULL], [NULL]);) 2025.11.13 09:22:05.441108 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:05.568717 [ 16233 ] {ca3d74e8-d413-45d0-a3fb-61960ab12328} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 44, line 45) (in query: SELECT JSONAllPathsWithTypes([NULL], [NULL], [NULL]);) 2025.11.13 09:22:05.606718 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:05.736498 [ 16233 ] {b3744e80-3b7f-4d24-bbb0-12b4d5fcb54f} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 45, line 46) (in query: SELECT JSONArrayLength([NULL], [NULL], [NULL]);) 2025.11.13 09:22:05.756679 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:05.934833 [ 18149 ] {b6f2e43d-090a-44ba-8570-6020b8275d10} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39020) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_zcemr8gu_test1.`../*.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x000000002f8e91d8 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8ea91d 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:05.948264 [ 18149 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x000000002f8e91d8 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8ea91d 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:06.019858 [ 16233 ] {fe1daff7-6c33-49a8-9101-b5f0d79844ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 46, line 47) (in query: SELECT JSONDynamicPaths([NULL], [NULL], [NULL]);) 2025.11.13 09:22:06.032817 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:06.048781 [ 3724 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 633.24 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:06.050697 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 633.24 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:06.055817 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 657.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:06.057536 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 657.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:06.254815 [ 16233 ] {9f1df304-854f-4632-9674-915c903e20a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 47, line 48) (in query: SELECT JSONDynamicPathsWithTypes([NULL], [NULL], [NULL]);) 2025.11.13 09:22:06.267140 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:06.331123 [ 16233 ] {e0de26b1-019a-4753-b9f3-ff91dd7c9dee} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: [NULL]: In scope SELECT JSONExtract([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 48, line 49) (in query: SELECT JSONExtract([NULL], [NULL], [NULL]);) 2025.11.13 09:22:06.411003 [ 16233 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: [NULL]: In scope SELECT JSONExtract([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) 2025.11.13 09:22:06.482754 [ 16233 ] {e0f750cc-5762-471b-9c8a-0f0e589f743a} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractArrayRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 49, line 50) (in query: SELECT JSONExtractArrayRaw([NULL], [NULL], [NULL]);) 2025.11.13 09:22:06.494161 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractArrayRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:06.639019 [ 16233 ] {bb23c402-9316-4511-810d-8ccede619da6} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractBool([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 50, line 51) (in query: SELECT JSONExtractBool([NULL], [NULL], [NULL]);) 2025.11.13 09:22:06.651905 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractBool([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:06.717519 [ 16233 ] {4402d852-cd47-4e8e-9c63-ee9308f2b5b9} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractFloat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 51, line 52) (in query: SELECT JSONExtractFloat([NULL], [NULL], [NULL]);) 2025.11.13 09:22:06.728978 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractFloat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:06.799907 [ 16233 ] {1cd2e871-2d8e-4f59-b649-bb1508064e01} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractInt([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 52, line 53) (in query: SELECT JSONExtractInt([NULL], [NULL], [NULL]);) 2025.11.13 09:22:06.813290 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractInt([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:06.883019 [ 16233 ] {c09ad3f4-bb73-4645-aac4-1f2dfc407dc6} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractKeys([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 53, line 54) (in query: SELECT JSONExtractKeys([NULL], [NULL], [NULL]);) 2025.11.13 09:22:06.929166 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractKeys([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:06.981377 [ 16233 ] {bcce219d-c810-42d3-8906-9040a6005e72} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: [NULL]: In scope SELECT JSONExtractKeysAndValues([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 54, line 55) (in query: SELECT JSONExtractKeysAndValues([NULL], [NULL], [NULL]);) 2025.11.13 09:22:06.992242 [ 16233 ] {} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: [NULL]: In scope SELECT JSONExtractKeysAndValues([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) 2025.11.13 09:22:07.112608 [ 17227 ] {2a31897f-1759-403f-8416-eca6bfa949cf} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39064) (comment: 02722_database_filesystem.sh) (query 2, line 3) (in query: SELECT COUNT(*) FROM "../02722_database_filesystem_test_zcemr8gu_iAC6/tmp.csv";), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x000000002f8e91d8 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8ea91d 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:07.125064 [ 17227 ] {} TCPHandler: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x000000002f8e91d8 5. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x000000002f8ea91d 6. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x000000002f8ec55c 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:458: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031add4fe 8. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1027: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4139 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x000000003111b046 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1551: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000003044bbec 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4366: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b29a0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:07.174926 [ 16047 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:07.175979 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:07.183445 [ 16047 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.56 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:07.184339 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.56 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:07.188604 [ 16047 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:07.189457 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:07.189420 [ 16233 ] {15dc340a-967f-4557-b3d7-653bf96e17a8} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractKeysAndValuesRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 55, line 56) (in query: SELECT JSONExtractKeysAndValuesRaw([NULL], [NULL], [NULL]);) 2025.11.13 09:22:07.200896 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractKeysAndValuesRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:07.215883 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:07.217897 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:07.355745 [ 16233 ] {432274c3-6287-4529-a5a9-9227b281dde7} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 56, line 57) (in query: SELECT JSONExtractRaw([NULL], [NULL], [NULL]);) 2025.11.13 09:22:07.367570 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:07.439668 [ 16233 ] {34485688-03c2-4def-9745-5048ec2de4ee} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 57, line 58) (in query: SELECT JSONExtractString([NULL], [NULL], [NULL]);) 2025.11.13 09:22:07.451502 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:07.529378 [ 16233 ] {2af074a0-a75b-4284-9dbe-ee6e69aab4ab} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractUInt([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 58, line 59) (in query: SELECT JSONExtractUInt([NULL], [NULL], [NULL]);) 2025.11.13 09:22:07.542542 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractUInt([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:07.606202 [ 16233 ] {29a300f4-f689-4e66-be56-7e4d93395d0b} executeQuery: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONHas([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 59, line 60) (in query: SELECT JSONHas([NULL], [NULL], [NULL]);) 2025.11.13 09:22:07.617607 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONHas([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:07.678082 [ 16233 ] {0a2cdaa7-cdfc-470a-a2e8-d858569e40fa} executeQuery: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONKey([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 60, line 61) (in query: SELECT JSONKey([NULL], [NULL], [NULL]);) 2025.11.13 09:22:07.688611 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONKey([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:07.759044 [ 16233 ] {d78c4857-9b59-46a2-b8d8-2b084a074570} executeQuery: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONLength([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 61, line 62) (in query: SELECT JSONLength([NULL], [NULL], [NULL]);) 2025.11.13 09:22:07.772296 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONLength([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:07.811670 [ 19621 ] {90177ad1-3fbd-4e46-82f1-7cad9773c8f8} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39050) (comment: 00293_shard_max_subquery_depth.sql) (query 2, line 5) (in query: SELECT 1 FROM remote('127.0.0.{1,2}', system.one) WHERE 1 GLOBAL IN (SELECT 1 FROM remote('127.0.0.{2,3}', system.one) WHERE 1 GLOBAL IN (SELECT 1 FROM remote('127.0.0.{2,3}', system.one) WHERE 1 GLOBAL IN (SELECT 1 FROM remote('127.0.0.{2,3}', system.one))));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003aa90dc2 18. ./build_docker/./src/Client/ConnectionPool.cpp:103: DB::ConnectionPool::get(DB::ConnectionTimeouts const&, DB::Settings const&, bool) @ 0x000000003aaf0e2c 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:51: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadb565 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 22. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 23. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:22:07.879005 [ 16233 ] {138a5dcc-5423-4861-9ed7-c124df0b256f} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 62, line 63) (in query: SELECT JSONMergePatch([NULL], [NULL], [NULL]);) 2025.11.13 09:22:07.891332 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:07.901508 [ 16215 ] {6add0e09-f8d1-4d57-9859-8d155a98b99a} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:33368). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33368) (comment: 00293_shard_max_subquery_depth.sql) (query 2, line 5) (in query: SELECT 1 AS `1` FROM `system`.`one` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x000000003aea4d5d 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:22:07.910717 [ 16215 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:33368). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x000000003aea4d5d 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:22:08.044225 [ 16233 ] {4c389e7d-7c41-462e-a3b8-8f431219cec0} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 63, line 64) (in query: SELECT JSONSharedDataPaths([NULL], [NULL], [NULL]);) 2025.11.13 09:22:08.057440 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:08.129892 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 597.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:08.131037 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 597.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:08.154080 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 596.95 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 8481): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:08.155868 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 596.95 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 8481): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:08.243383 [ 16233 ] {8ca15679-4672-4341-8a9e-43fdd3a9c9f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 64, line 65) (in query: SELECT JSONSharedDataPathsWithTypes([NULL], [NULL], [NULL]);) 2025.11.13 09:22:08.257019 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:08.328552 [ 16233 ] {2ea5a990-da8b-4b34-bc5c-b58aa149f981} executeQuery: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONType([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 65, line 66) (in query: SELECT JSONType([NULL], [NULL], [NULL]);) 2025.11.13 09:22:08.345840 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONType([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:08.408023 [ 16233 ] {9bc859ec-1f07-427b-8e90-d3718f2b11c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 66, line 67) (in query: SELECT JSON_ARRAY_LENGTH([NULL], [NULL], [NULL]);) 2025.11.13 09:22:08.419739 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:08.503990 [ 16233 ] {6c23ae44-174a-420d-af36-cadd4c0dbbd6} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_EXISTS([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 67, line 68) (in query: SELECT JSON_EXISTS([NULL], [NULL], [NULL]);) 2025.11.13 09:22:08.601170 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_EXISTS([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:08.668935 [ 16233 ] {eb8be6e2-21f2-4e46-b853-4d27f812fcbc} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_QUERY([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 68, line 69) (in query: SELECT JSON_QUERY([NULL], [NULL], [NULL]);) 2025.11.13 09:22:08.679669 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_QUERY([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:08.744129 [ 16233 ] {7d96fb23-ae05-43fe-8ccd-be8bca53effe} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_VALUE([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 69, line 70) (in query: SELECT JSON_VALUE([NULL], [NULL], [NULL]);) 2025.11.13 09:22:08.756304 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_VALUE([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:08.868554 [ 16233 ] {a96ad31a-05b4-4531-ae65-59b2817b28e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 70, line 71) (in query: SELECT L1Distance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:08.879918 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:09.020924 [ 17227 ] {ba47f2e4-a4d7-4b42-9d78-558560f3b38e} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39142) (comment: 02722_database_filesystem.sh) (query 2, line 3) (in query: CREATE DATABASE test_zcemr8gu_test2 ENGINE = Filesystem('/tmp');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6d45 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:22:09.034630 [ 17227 ] {} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6d45 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:22:09.045172 [ 16233 ] {dcbe67a6-f75c-4dbf-b5d4-6b3d5f4de44b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 71, line 72) (in query: SELECT L1Norm([NULL], [NULL], [NULL]);) 2025.11.13 09:22:09.056961 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:09.126338 [ 16233 ] {67b177e3-affb-421e-8d68-4d0fba2e81cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 72, line 73) (in query: SELECT L1Normalize([NULL], [NULL], [NULL]);) 2025.11.13 09:22:09.136636 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 616.59 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:09.138760 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 616.59 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:09.139223 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:09.158616 [ 3729 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 606.25 MiB (attempt to allocate chunk of 1.29 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_188_188_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1532): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:09.160452 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_192_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 606.25 MiB (attempt to allocate chunk of 1.29 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_188_188_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1532): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:09.162746 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 606.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:09.163604 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 606.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:09.203476 [ 16233 ] {4f7497f2-7b63-4183-bea0-a5752089ac71} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 73, line 74) (in query: SELECT L2Distance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:09.214786 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:09.276880 [ 16233 ] {27b5ad42-e546-4406-a55f-55f79f76fb67} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 74, line 75) (in query: SELECT L2Norm([NULL], [NULL], [NULL]);) 2025.11.13 09:22:09.288757 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:09.361418 [ 16233 ] {871e821e-6072-45f4-a309-497d30ed9318} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 75, line 76) (in query: SELECT L2Normalize([NULL], [NULL], [NULL]);) 2025.11.13 09:22:09.374706 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:09.383466 [ 19621 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003aa90dc2 18. ./build_docker/./src/Client/ConnectionPool.cpp:103: DB::ConnectionPool::get(DB::ConnectionTimeouts const&, DB::Settings const&, bool) @ 0x000000003aaf0e2c 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:51: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadb565 20. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 21. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 22. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 23. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 8. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:324: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x0000000038f13249 9. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:426: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x0000000038f0393c 10. ./build_docker/./src/Storages/StorageDistributed.cpp:856: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003846a5ef 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:278: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x0000000038f114db 17. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:426: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x0000000038f0393c 18. ./build_docker/./src/Storages/StorageDistributed.cpp:856: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003846a5ef 19. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 20. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 21. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 22. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 23. ./build_docker/./src/Planner/Planner.cpp:1168: DB::Planner::buildPlanForQueryNode() @ 0x0000000032c06029 24. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 25. ./build_docker/./src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000032be23f6 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd625b 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 32. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 33. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 34. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 35. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 36. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 37. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 38. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 39. ? @ 0x00007fa150622ac3 40. ? @ 0x00007fa1506b4850 2025.11.13 09:22:09.497137 [ 16233 ] {1299f083-50c7-46de-8cb7-71590ce81653} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 76, line 77) (in query: SELECT L2SquaredDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:09.512096 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:09.670456 [ 16233 ] {db417125-df0b-4e59-b16b-b38ff788f898} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 77, line 78) (in query: SELECT L2SquaredNorm([NULL], [NULL], [NULL]);) 2025.11.13 09:22:09.682628 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:09.744242 [ 16233 ] {bb16744c-e7d6-4e76-8444-20c78b7a7521} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT LAST_DAY([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 78, line 79) (in query: SELECT LAST_DAY([NULL], [NULL], [NULL]);) 2025.11.13 09:22:09.754079 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT LAST_DAY([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:09.818362 [ 16233 ] {7439d457-2ce2-45e9-bdc6-629f4490627d} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 79, line 80) (in query: SELECT LinfDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:09.828551 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:10.143924 [ 16233 ] {b54b1cfa-2af3-4151-8036-592659c80739} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 80, line 81) (in query: SELECT LinfNorm([NULL], [NULL], [NULL]);) 2025.11.13 09:22:10.214275 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:10.266388 [ 6078 ] {c84c63ad-ea13-4255-aa98-750ca3ddf41c} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.62 MiB (attempt to allocate chunk of 1.22 MiB), maximum: 9.31 GiB: While executing Memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56624) (comment: 02941_variant_type_2.sh) (query 8, line 8) (in query: select count() from test where isNotNull(v.`LowCardinality(String)`);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 9. ./src/Common/HashTable/HashTable.h:538: HashTable, DB::ColumnString, true, true>, DB::ReverseIndexHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x00000000379cd67b 10. ./src/Common/HashTable/HashTable.h:926: DB::ReverseIndex::insert(StringRef) @ 0x0000000037874a37 11. ./src/Columns/ColumnUnique.h:602: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long) @ 0x00000000379cf839 12. ./src/Columns/ColumnUnique.h:569: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long)::'lambda'(unsigned long&)::operator()(unsigned long&) const @ 0x00000000379ce711 13. ./src/Columns/ColumnUnique.h:605: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long) @ 0x00000000379c7dc5 14. ./src/Columns/ColumnUnique.h:653: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long)::'lambda'(auto)::operator()(auto) const @ 0x0000000037870541 15. ./src/Columns/ColumnUnique.h:661: DB::ColumnUnique::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003786fb54 16. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:949: DB::ColumnLowCardinality::Dictionary::compact(DB::IColumnUnique const&, COW::mutable_ptr&) @ 0x000000003754d4b6 17. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:938: DB::ColumnLowCardinality::Dictionary::compact(COW::mutable_ptr&) @ 0x000000003754da73 18. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:597: DB::ColumnLowCardinality::compactInplace() @ 0x0000000037546270 19. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:348: DB::ColumnLowCardinality::cloneNullable() const @ 0x000000003754607f 20. ./build_docker/./src/Columns/ColumnNullable.cpp:1020: DB::makeNullableOrLowCardinalityNullableSafe(COW::immutable_ptr const&) @ 0x00000000376026ed 21. ./build_docker/./src/DataTypes/Serializations/SerializationVariantElement.cpp:333: DB::SerializationVariantElement::VariantSubcolumnCreator::create(COW::immutable_ptr const&) const @ 0x000000002f84ac94 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:486: DB::ISerialization::createFromPath(DB::ISerialization::SubstreamPath const&, unsigned long) @ 0x000000002f58fe4f 23. ./build_docker/./src/DataTypes/IDataType.cpp:139: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, DB::ISerialization::SubstreamData const&, bool)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002f4c1915 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 25. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:101: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f817ab1 26. ./build_docker/./src/DataTypes/IDataType.cpp:170: DB::IDataType::getSubcolumnData(std::basic_string_view>, DB::ISerialization::SubstreamData const&, bool) @ 0x000000002f4b4d86 27. ./build_docker/./src/DataTypes/IDataType.cpp:217: DB::IDataType::tryGetSubcolumn(std::basic_string_view>, COW::immutable_ptr const&) const @ 0x000000002f4b8964 28. ./build_docker/./src/Interpreters/getColumnFromBlock.cpp:58: DB::tryGetSubcolumnFromBlock(DB::Block const&, std::shared_ptr const&, DB::NameAndTypePair const&) @ 0x0000000038fcc19d 29. ./build_docker/./src/Processors/QueryPlan/ReadFromMemoryStorageStep.cpp:72: DB::MemorySource::generate() @ 0x000000003c265f6c 30. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 31. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 2025.11.13 09:22:10.283419 [ 16233 ] {3df4b02b-a3fd-4d66-a5e8-495a660ba2fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 81, line 82) (in query: SELECT LinfNormalize([NULL], [NULL], [NULL]);) 2025.11.13 09:22:10.283944 [ 6078 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.62 MiB (attempt to allocate chunk of 1.22 MiB), maximum: 9.31 GiB: While executing Memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 9. ./src/Common/HashTable/HashTable.h:538: HashTable, DB::ColumnString, true, true>, DB::ReverseIndexHash, HashTableGrowerWithPrecalculation<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x00000000379cd67b 10. ./src/Common/HashTable/HashTable.h:926: DB::ReverseIndex::insert(StringRef) @ 0x0000000037874a37 11. ./src/Columns/ColumnUnique.h:602: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long) @ 0x00000000379cf839 12. ./src/Columns/ColumnUnique.h:569: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long)::'lambda'(unsigned long&)::operator()(unsigned long&) const @ 0x00000000379ce711 13. ./src/Columns/ColumnUnique.h:605: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeImpl(DB::IColumn const&, unsigned long, unsigned long, unsigned long, DB::ColumnVector::MutablePtr&&, DB::ReverseIndex*, unsigned long) @ 0x00000000379c7dc5 14. ./src/Columns/ColumnUnique.h:653: COW::mutable_ptr DB::ColumnUnique::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long)::'lambda'(auto)::operator()(auto) const @ 0x0000000037870541 15. ./src/Columns/ColumnUnique.h:661: DB::ColumnUnique::uniqueInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003786fb54 16. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:949: DB::ColumnLowCardinality::Dictionary::compact(DB::IColumnUnique const&, COW::mutable_ptr&) @ 0x000000003754d4b6 17. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:938: DB::ColumnLowCardinality::Dictionary::compact(COW::mutable_ptr&) @ 0x000000003754da73 18. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:597: DB::ColumnLowCardinality::compactInplace() @ 0x0000000037546270 19. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:348: DB::ColumnLowCardinality::cloneNullable() const @ 0x000000003754607f 20. ./build_docker/./src/Columns/ColumnNullable.cpp:1020: DB::makeNullableOrLowCardinalityNullableSafe(COW::immutable_ptr const&) @ 0x00000000376026ed 21. ./build_docker/./src/DataTypes/Serializations/SerializationVariantElement.cpp:333: DB::SerializationVariantElement::VariantSubcolumnCreator::create(COW::immutable_ptr const&) const @ 0x000000002f84ac94 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:486: DB::ISerialization::createFromPath(DB::ISerialization::SubstreamPath const&, unsigned long) @ 0x000000002f58fe4f 23. ./build_docker/./src/DataTypes/IDataType.cpp:139: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, DB::ISerialization::SubstreamData const&, bool)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002f4c1915 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 25. ./build_docker/./src/DataTypes/Serializations/SerializationVariant.cpp:101: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f817ab1 26. ./build_docker/./src/DataTypes/IDataType.cpp:170: DB::IDataType::getSubcolumnData(std::basic_string_view>, DB::ISerialization::SubstreamData const&, bool) @ 0x000000002f4b4d86 27. ./build_docker/./src/DataTypes/IDataType.cpp:217: DB::IDataType::tryGetSubcolumn(std::basic_string_view>, COW::immutable_ptr const&) const @ 0x000000002f4b8964 28. ./build_docker/./src/Interpreters/getColumnFromBlock.cpp:58: DB::tryGetSubcolumnFromBlock(DB::Block const&, std::shared_ptr const&, DB::NameAndTypePair const&) @ 0x0000000038fcc19d 29. ./build_docker/./src/Processors/QueryPlan/ReadFromMemoryStorageStep.cpp:72: DB::MemorySource::generate() @ 0x000000003c265f6c 30. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 31. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:22:10.295914 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:10.495265 [ 16233 ] {8bef045a-745e-47a3-824c-6883bf810cd9} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nullable(Nothing). Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT LpDistance([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 82, line 83) (in query: SELECT LpDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:10.507113 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nullable(Nothing). Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT LpDistance([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:10.569214 [ 16233 ] {02dd3b7b-803b-4479-a3e7-5732fef4dd01} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 83, line 84) (in query: SELECT LpNorm([NULL], [NULL], [NULL]);) 2025.11.13 09:22:10.580589 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:10.653659 [ 16233 ] {3deab39f-f458-42aa-b78b-6a630dbcc97c} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 84, line 85) (in query: SELECT LpNormalize([NULL], [NULL], [NULL]);) 2025.11.13 09:22:10.665539 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:10.731240 [ 16233 ] {d31612d7-c0c9-4fba-9a95-76bee20f0ff5} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 85, line 86) (in query: SELECT MACNumToString([NULL], [NULL], [NULL]);) 2025.11.13 09:22:10.744511 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:10.900585 [ 16233 ] {7e3d7153-0963-4f04-b92d-183568f5cd52} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 86, line 87) (in query: SELECT MACStringToNum([NULL], [NULL], [NULL]);) 2025.11.13 09:22:10.911714 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:10.963891 [ 16047 ] {c9b675e5-b0e3-4a19-90fa-e08c0c1315f9} executeQuery: Code: 36. DB::Exception: Path does not exist: /var/lib/clickhouse/user_files/relative_unknown_dir. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39218) (comment: 02722_database_filesystem.sh) (query 2, line 3) (in query: CREATE DATABASE test_zcemr8gu_test2 ENGINE = Filesystem('relative_unknown_dir');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:61: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6946 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:22:10.976029 [ 16047 ] {} TCPHandler: Code: 36. DB::Exception: Path does not exist: /var/lib/clickhouse/user_files/relative_unknown_dir. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:61: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6946 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:22:11.020771 [ 16233 ] {a3e94ff9-2a90-46d1-865d-650140c33813} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 87, line 88) (in query: SELECT MACStringToOUI([NULL], [NULL], [NULL]);) 2025.11.13 09:22:11.027795 [ 18106 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 636.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:11.028999 [ 18106 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 636.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:11.035282 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:11.109464 [ 16233 ] {6732807e-a74a-4a63-850f-ccc9875b1007} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 88, line 89) (in query: SELECT MAP_FROM_ARRAYS([NULL], [NULL], [NULL]);) 2025.11.13 09:22:11.120963 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:11.150513 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 636.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:11.152635 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 636.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:11.190439 [ 16233 ] {e3eccc62-14a1-49b1-8571-81b4dbdf7c97} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 89, line 90) (in query: SELECT MD4([NULL], [NULL], [NULL]);) 2025.11.13 09:22:11.293350 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:11.348538 [ 16233 ] {09a3c730-3cc3-4398-95c6-31f3b11e5e90} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 90, line 91) (in query: SELECT MD5([NULL], [NULL], [NULL]);) 2025.11.13 09:22:11.490285 [ 16693 ] {337cad20-ec47-4f8b-a641-44573542d02f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39028) (comment: 02421_decimal_in_precision_issue_41125.sql) (query 22, line 31) (in query: SELECT count() == 0 FROM dtest WHERE a IN toDecimal256('33.3000', 4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:11.511776 [ 16693 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:22:11.517122 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:11.583266 [ 16233 ] {7645fe37-7468-4182-9764-6570601d1a78} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT MILLISECOND([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 91, line 92) (in query: SELECT MILLISECOND([NULL], [NULL], [NULL]);) 2025.11.13 09:22:11.684305 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT MILLISECOND([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:11.825457 [ 16233 ] {014e6c12-ea77-4d8c-8ea9-7b46e11f6e62} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT MINUTE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 92, line 93) (in query: SELECT MINUTE([NULL], [NULL], [NULL]);) 2025.11.13 09:22:11.836912 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT MINUTE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:11.900950 [ 16233 ] {34fe1bbf-ebbf-4132-9a82-4ec22c8c3e3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT MONTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 93, line 94) (in query: SELECT MONTH([NULL], [NULL], [NULL]);) 2025.11.13 09:22:11.906176 [ 16047 ] {be5cd6ee-7167-40db-80c1-78091ff86046} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_zcemr8gu_test1.tmp2.csv' in scope SELECT COUNT(*) FROM test_zcemr8gu_test1.`tmp2.csv`. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44964) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_zcemr8gu_test1.`tmp2.csv`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:22:11.911273 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT MONTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:11.918211 [ 16047 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_zcemr8gu_test1.tmp2.csv' in scope SELECT COUNT(*) FROM test_zcemr8gu_test1.`tmp2.csv`. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:22:12.098233 [ 16233 ] {f31137da-eb59-48e8-991a-ef128f47ff5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 94, line 95) (in query: SELECT OCTET_LENGTH([NULL], [NULL], [NULL]);) 2025.11.13 09:22:12.149953 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:12.219331 [ 16233 ] {659cf409-ef86-4764-8461-a5e742590afd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT QUARTER([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 95, line 96) (in query: SELECT QUARTER([NULL], [NULL], [NULL]);) 2025.11.13 09:22:12.230575 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT QUARTER([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:12.391852 [ 16233 ] {aa24b5a2-cb88-4b91-91fb-615dbd0b686f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT REGEXP_EXTRACT([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 96, line 97) (in query: SELECT REGEXP_EXTRACT([NULL], [NULL], [NULL]);) 2025.11.13 09:22:12.402876 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT REGEXP_EXTRACT([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:12.466440 [ 16233 ] {f305db41-fced-4d99-9917-1d5963321a26} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 97, line 98) (in query: SELECT REGEXP_MATCHES([NULL], [NULL], [NULL]);) 2025.11.13 09:22:12.477582 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:12.629393 [ 16233 ] {7e12e260-5c57-48e4-a242-80a5bd9a47bc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT REGEXP_REPLACE([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 98, line 99) (in query: SELECT REGEXP_REPLACE([NULL], [NULL], [NULL]);) 2025.11.13 09:22:12.642194 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT REGEXP_REPLACE([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:12.701627 [ 16233 ] {87faa6b5-2897-4a50-ad6d-6b03f12bed4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 99, line 100) (in query: SELECT RIPEMD160([NULL], [NULL], [NULL]);) 2025.11.13 09:22:12.712513 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function RIPEMD160 doesn't match: passed 3, should be 1: In scope SELECT RIPEMD160([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:12.782617 [ 16233 ] {b61c7011-a43e-4895-91d3-82ad04581e13} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 100, line 101) (in query: SELECT SCHEMA([NULL], [NULL], [NULL]);) 2025.11.13 09:22:12.793659 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:12.896204 [ 16233 ] {2d8ef1e9-a81e-4bbb-8ade-3762ba24784a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT SECOND([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 101, line 102) (in query: SELECT SECOND([NULL], [NULL], [NULL]);) 2025.11.13 09:22:12.979986 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT SECOND([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:13.043412 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 607.16 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:13.045265 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 607.16 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:13.058834 [ 16233 ] {3df0c5b6-ed44-4924-892f-9d94d979ea7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 102, line 103) (in query: SELECT SHA1([NULL], [NULL], [NULL]);) 2025.11.13 09:22:13.100712 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:13.201990 [ 16233 ] {5cd08ffd-120a-428f-abbf-19e758b19401} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 103, line 104) (in query: SELECT SHA224([NULL], [NULL], [NULL]);) 2025.11.13 09:22:13.265077 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:13.391511 [ 16233 ] {acf5de68-9055-4538-b53e-d0e34fd3c054} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 104, line 105) (in query: SELECT SHA256([NULL], [NULL], [NULL]);) 2025.11.13 09:22:13.402619 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:13.466525 [ 16233 ] {a48747ff-9c94-47d7-84ef-4e6812217a02} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 105, line 106) (in query: SELECT SHA384([NULL], [NULL], [NULL]);) 2025.11.13 09:22:13.476765 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:13.541863 [ 16233 ] {79d911a8-0209-410c-aa62-d6d0fd4501a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 106, line 107) (in query: SELECT SHA512([NULL], [NULL], [NULL]);) 2025.11.13 09:22:13.553096 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:13.698945 [ 16233 ] {0eeab556-56b4-4adc-a730-3aaea9689830} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 107, line 108) (in query: SELECT SHA512_256([NULL], [NULL], [NULL]);) 2025.11.13 09:22:13.710528 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:13.775903 [ 16233 ] {324cf8d5-fa54-46a4-87fd-749a3a61c5e4} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 108, line 109) (in query: SELECT STD([NULL], [NULL], [NULL]);) 2025.11.13 09:22:13.787241 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:13.846650 [ 16233 ] {f25a3f89-b3f3-43ca-8c3a-793c3180819c} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 109, line 110) (in query: SELECT STDDEV_POP([NULL], [NULL], [NULL]);) 2025.11.13 09:22:13.858712 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:13.916080 [ 16233 ] {31505256-8129-4bf9-ac65-56dbc7699861} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 110, line 111) (in query: SELECT STDDEV_SAMP([NULL], [NULL], [NULL]);) 2025.11.13 09:22:13.927347 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:13.991870 [ 16233 ] {1220767e-ca08-40ef-a773-0ec814a6ce58} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndex, String expected: In scope SELECT SUBSTRING_INDEX([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 111, line 112) (in query: SELECT SUBSTRING_INDEX([NULL], [NULL], [NULL]);) 2025.11.13 09:22:14.002338 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndex, String expected: In scope SELECT SUBSTRING_INDEX([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:14.128053 [ 16233 ] {3e1bf426-1932-4068-8db5-aa04a67bdbf9} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 112, line 113) (in query: SELECT SVG([NULL], [NULL], [NULL]);) 2025.11.13 09:22:14.139187 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:14.206866 [ 16233 ] {aa4b0040-242d-4e81-8e56-d4cdf9a25f5a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 113, line 114) (in query: SELECT TIMESTAMP_DIFF([NULL], [NULL], [NULL]);) 2025.11.13 09:22:14.218447 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:14.278568 [ 16233 ] {0d59c0d0-b40b-4ce8-8a7b-896483980a3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 114, line 115) (in query: SELECT TO_BASE64([NULL], [NULL], [NULL]);) 2025.11.13 09:22:14.289683 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:14.349311 [ 16233 ] {6af974bc-139d-45d2-92a3-00f34f28bf65} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT TO_DAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 115, line 116) (in query: SELECT TO_DAYS([NULL], [NULL], [NULL]);) 2025.11.13 09:22:14.360458 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT TO_DAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:14.527488 [ 16233 ] {5b894911-7248-456a-9607-ca22b2ed7d05} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT TO_UNIXTIME([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 116, line 117) (in query: SELECT TO_UNIXTIME([NULL], [NULL], [NULL]);) 2025.11.13 09:22:14.541192 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT TO_UNIXTIME([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:14.667724 [ 16233 ] {4bceb843-9f5d-4701-b61a-a9c1c563c6a7} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 117, line 118) (in query: SELECT ULIDStringToDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:22:14.679009 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:14.746833 [ 16233 ] {766bc87e-fc29-4dec-be65-90cae33051ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 3, should be 1 or 2.: In scope SELECT URLHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 118, line 119) (in query: SELECT URLHash([NULL], [NULL], [NULL]);) 2025.11.13 09:22:14.757885 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 3, should be 1 or 2.: In scope SELECT URLHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:14.846369 [ 16233 ] {bcc59f29-fcc8-42b0-9f22-1738c8b67dcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 119, line 120) (in query: SELECT URLHierarchy([NULL], [NULL], [NULL]);) 2025.11.13 09:22:14.858325 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:14.919132 [ 16233 ] {2f491094-17d7-4a48-8ed5-ebb069856be9} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 120, line 121) (in query: SELECT URLPathHierarchy([NULL], [NULL], [NULL]);) 2025.11.13 09:22:14.930229 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:14.994922 [ 16233 ] {ca8e08ba-d861-4b53-87a7-c2b29ff54f02} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 121, line 122) (in query: SELECT UTCTimestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:22:15.006584 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:15.200304 [ 16233 ] {1a0288ca-eaba-405b-ad7a-026d1fc5f236} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 122, line 123) (in query: SELECT UTC_timestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:22:15.214905 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:15.404006 [ 16233 ] {d8cd25fd-dae6-4be7-a713-59066425f3cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDNumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 123, line 124) (in query: SELECT UUIDNumToString([NULL], [NULL], [NULL]);) 2025.11.13 09:22:15.415861 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDNumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:15.505695 [ 3726 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 697.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:15.507743 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 697.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:15.615990 [ 16233 ] {90d05481-e6db-4a97-bc2d-433c51b58b0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDStringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 124, line 125) (in query: SELECT UUIDStringToNum([NULL], [NULL], [NULL]);) 2025.11.13 09:22:15.627731 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDStringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:15.758739 [ 16233 ] {e4972138-1351-4d18-92ac-00933f3c007c} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 125, line 126) (in query: SELECT UUIDToNum([NULL], [NULL], [NULL]);) 2025.11.13 09:22:15.770750 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:16.025064 [ 16233 ] {69d461e8-04d8-402d-ac48-42d61c67bc68} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 126, line 127) (in query: SELECT UUIDv7ToDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:22:16.036763 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:16.101016 [ 16233 ] {28c060a3-e99e-400e-9498-27afef82b0a7} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 127, line 128) (in query: SELECT VAR_POP([NULL], [NULL], [NULL]);) 2025.11.13 09:22:16.111410 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:16.226482 [ 16233 ] {2dc35b34-895a-4578-ac6b-812166fa7a12} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 128, line 129) (in query: SELECT VAR_SAMP([NULL], [NULL], [NULL]);) 2025.11.13 09:22:16.240616 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:16.306073 [ 16233 ] {1376c08e-6e23-49df-ba11-4753c4e6040e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT YEAR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 129, line 130) (in query: SELECT YEAR([NULL], [NULL], [NULL]);) 2025.11.13 09:22:16.317166 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT YEAR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:16.381786 [ 16233 ] {50a1fa32-99c7-42e0-82ce-3425f130a451} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 130, line 131) (in query: SELECT YYYYMMDDToDate([NULL], [NULL], [NULL]);) 2025.11.13 09:22:16.392955 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:16.453070 [ 16141 ] {f0f77d2c-281a-4a00-9138-d256717094e9} executeQuery: Code: 57. DB::Exception: Table test_7.welch_ttest already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45134) (comment: 01558_ttest.sql) (query 7, line 10) (in query: CREATE TABLE welch_ttest (left Float64, right Float64) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:22:16.460739 [ 16233 ] {069e70fc-cdf1-4a4b-b8f7-d088158e6e72} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 131, line 132) (in query: SELECT YYYYMMDDToDate32([NULL], [NULL], [NULL]);) 2025.11.13 09:22:16.464900 [ 16141 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.welch_ttest already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:22:16.471797 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:16.531825 [ 16233 ] {5d0855fd-4e00-4731-999e-7b050d738732} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 132, line 133) (in query: SELECT YYYYMMDDhhmmssToDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:22:16.542971 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:16.620292 [ 16233 ] {3d8bcd52-6133-4b99-a51c-c0d245c5e7fc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT YYYYMMDDhhmmssToDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 133, line 134) (in query: SELECT YYYYMMDDhhmmssToDateTime64([NULL], [NULL], [NULL]);) 2025.11.13 09:22:16.631295 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT YYYYMMDDhhmmssToDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:16.755608 [ 16233 ] {4c065290-c013-4b04-9d03-1a39634a09d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 134, line 135) (in query: SELECT _CAST([NULL], [NULL], [NULL]);) 2025.11.13 09:22:16.767524 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:16.940694 [ 16233 ] {e340c1d5-15bc-43bd-b7b2-c4d42bdf27f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 135, line 136) (in query: SELECT __actionName([NULL], [NULL], [NULL]);) 2025.11.13 09:22:16.953387 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:17.106321 [ 16233 ] {94a4793b-342c-41ce-8d92-d6b8cd1b1ef6} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 136, line 137) (in query: SELECT __bitBoolMaskAnd([NULL], [NULL], [NULL]);) 2025.11.13 09:22:17.117866 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:17.254476 [ 16233 ] {7daa802b-6465-4b86-ac9a-07a9f8e52cd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 137, line 138) (in query: SELECT __bitBoolMaskOr([NULL], [NULL], [NULL]);) 2025.11.13 09:22:17.266869 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:17.333945 [ 16233 ] {3af24b60-b53a-4ada-91ff-8decf88d0979} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 138, line 139) (in query: SELECT __bitSwapLastTwo([NULL], [NULL], [NULL]);) 2025.11.13 09:22:17.345388 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:17.404782 [ 16233 ] {bdb4cd7b-0a29-4a5d-971c-f24d0de825da} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 139, line 140) (in query: SELECT __bitWrapperFunc([NULL], [NULL], [NULL]);) 2025.11.13 09:22:17.416903 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:17.488733 [ 16233 ] {7a34b2c9-f1d3-4fdb-b2ba-6bde5011ed9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 140, line 141) (in query: SELECT __getScalar([NULL], [NULL], [NULL]);) 2025.11.13 09:22:17.503909 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:17.531448 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 699.00 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:17.533351 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 699.00 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:17.613000 [ 16233 ] {c32dd841-7be1-490d-a720-715f3a352395} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 141, line 142) (in query: SELECT __scalarSubqueryResult([NULL], [NULL], [NULL]);) 2025.11.13 09:22:17.624319 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:17.683763 [ 16233 ] {2e3825bb-c4a2-49f2-afed-4709e2db5b79} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 142, line 143) (in query: SELECT abs([NULL], [NULL], [NULL]);) 2025.11.13 09:22:17.697250 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:17.763420 [ 16233 ] {790b11e3-c80d-44e6-beaf-dff5c7f10a53} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 143, line 144) (in query: SELECT accurateCast([NULL], [NULL], [NULL]);) 2025.11.13 09:22:17.775165 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:17.840165 [ 16233 ] {28dd21da-14b7-4574-9740-850bee6bc6b3} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Array(Nullable(Nothing)): In scope SELECT accurateCastOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 144, line 145) (in query: SELECT accurateCastOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:17.852164 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Array(Nullable(Nothing)): In scope SELECT accurateCastOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:17.939736 [ 16233 ] {b9014425-9c42-48d5-bd4d-ae3be7b6084d} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 145, line 146) (in query: SELECT accurateCastOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:22:17.953373 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:18.100699 [ 16233 ] {0e5d184a-8585-4cbc-9b7a-85b06675768d} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 146, line 147) (in query: SELECT acos([NULL], [NULL], [NULL]);) 2025.11.13 09:22:18.112669 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:18.296346 [ 16233 ] {75131c0a-bb1b-4a23-8131-066c91cf8790} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 147, line 148) (in query: SELECT acosh([NULL], [NULL], [NULL]);) 2025.11.13 09:22:18.310543 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:18.397713 [ 16233 ] {92c11c71-e477-4a5a-b0c8-ca4825c01e38} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 148, line 149) (in query: SELECT addDate([NULL], [NULL], [NULL]);) 2025.11.13 09:22:18.451924 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:18.516760 [ 16233 ] {faf7d0e6-f529-43f9-8f5e-e0aa8167b8d7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addDays. Must be a DateTime/DateTime64: In scope SELECT addDays([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 149, line 150) (in query: SELECT addDays([NULL], [NULL], [NULL]);) 2025.11.13 09:22:18.530600 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addDays. Must be a DateTime/DateTime64: In scope SELECT addDays([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:18.601274 [ 16233 ] {e7ed0ba0-e249-4d3e-a0f6-f53dfb2ead5a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addHours. Must be a DateTime/DateTime64: In scope SELECT addHours([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 150, line 151) (in query: SELECT addHours([NULL], [NULL], [NULL]);) 2025.11.13 09:22:18.611785 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addHours. Must be a DateTime/DateTime64: In scope SELECT addHours([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:18.692687 [ 16233 ] {e03cf1ba-69a0-484e-b64e-456e562df615} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 151, line 152) (in query: SELECT addInterval([NULL], [NULL], [NULL]);) 2025.11.13 09:22:18.723137 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:18.812839 [ 16233 ] {09ff27b5-cdb5-4ecd-865f-fb81a7292a34} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMicroseconds. Must be a DateTime/DateTime64: In scope SELECT addMicroseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 152, line 153) (in query: SELECT addMicroseconds([NULL], [NULL], [NULL]);) 2025.11.13 09:22:18.828326 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMicroseconds. Must be a DateTime/DateTime64: In scope SELECT addMicroseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:19.017741 [ 16233 ] {b116a6b8-ed5c-4252-895c-057f490178fb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMilliseconds. Must be a DateTime/DateTime64: In scope SELECT addMilliseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 153, line 154) (in query: SELECT addMilliseconds([NULL], [NULL], [NULL]);) 2025.11.13 09:22:19.030679 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMilliseconds. Must be a DateTime/DateTime64: In scope SELECT addMilliseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:19.094100 [ 16233 ] {234916cb-8b3d-4bf3-a519-8b009ae10d7d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope SELECT addMinutes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 154, line 155) (in query: SELECT addMinutes([NULL], [NULL], [NULL]);) 2025.11.13 09:22:19.104800 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope SELECT addMinutes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:19.169510 [ 16233 ] {074de856-d588-420e-a159-d124c98c2465} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMonths. Must be a DateTime/DateTime64: In scope SELECT addMonths([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 155, line 156) (in query: SELECT addMonths([NULL], [NULL], [NULL]);) 2025.11.13 09:22:19.180405 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMonths. Must be a DateTime/DateTime64: In scope SELECT addMonths([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:19.343498 [ 16233 ] {d5f917e5-c8c2-4d20-964f-eff8d4051928} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addNanoseconds. Must be a DateTime/DateTime64: In scope SELECT addNanoseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 156, line 157) (in query: SELECT addNanoseconds([NULL], [NULL], [NULL]);) 2025.11.13 09:22:19.355630 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addNanoseconds. Must be a DateTime/DateTime64: In scope SELECT addNanoseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:19.419634 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 636.28 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:19.421609 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 636.28 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:19.477936 [ 16233 ] {4d8a58d6-0f82-4995-875d-6164c4baea3a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope SELECT addQuarters([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 157, line 158) (in query: SELECT addQuarters([NULL], [NULL], [NULL]);) 2025.11.13 09:22:19.569203 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope SELECT addQuarters([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:19.639337 [ 16233 ] {31199ee0-1c3d-4522-80ea-cf459f5fd20f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope SELECT addSeconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 158, line 159) (in query: SELECT addSeconds([NULL], [NULL], [NULL]);) 2025.11.13 09:22:19.651622 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope SELECT addSeconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:19.801762 [ 16233 ] {7817fc6e-a72e-4a6f-ab88-4095bd162baf} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 159, line 160) (in query: SELECT addTupleOfIntervals([NULL], [NULL], [NULL]);) 2025.11.13 09:22:19.812578 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:19.909510 [ 16233 ] {21c093ff-bcbd-48a3-8066-33e0e37bafa1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope SELECT addWeeks([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 160, line 161) (in query: SELECT addWeeks([NULL], [NULL], [NULL]);) 2025.11.13 09:22:19.923938 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope SELECT addWeeks([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:20.002496 [ 16233 ] {45274103-93cf-4aae-984e-cad60393d183} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addYears. Must be a DateTime/DateTime64: In scope SELECT addYears([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 161, line 162) (in query: SELECT addYears([NULL], [NULL], [NULL]);) 2025.11.13 09:22:20.014806 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addYears. Must be a DateTime/DateTime64: In scope SELECT addYears([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:20.120949 [ 16233 ] {344dd973-7e35-474f-b6bb-177629d0872b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 162, line 163) (in query: SELECT addressToLine([NULL], [NULL], [NULL]);) 2025.11.13 09:22:20.180618 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:20.241407 [ 16233 ] {f8e85aa2-a767-4d30-852f-15e7f4f8e27f} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 163, line 164) (in query: SELECT addressToLineWithInlines([NULL], [NULL], [NULL]);) 2025.11.13 09:22:20.253810 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:20.331467 [ 16233 ] {3f841318-9a6c-4b76-8673-331dadae57e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 164, line 165) (in query: SELECT addressToSymbol([NULL], [NULL], [NULL]);) 2025.11.13 09:22:20.344490 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:20.404841 [ 16233 ] {a62717d9-cd9c-4053-a37b-f487d0d2970f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_decrypt_mysql'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT aes_decrypt_mysql([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 165, line 166) (in query: SELECT aes_decrypt_mysql([NULL], '[HIDDEN]')) 2025.11.13 09:22:20.416934 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_decrypt_mysql'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT aes_decrypt_mysql([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:20.479326 [ 16233 ] {f8cf802d-2738-4a40-8484-7472d866affa} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: Array(Nullable(Nothing)): In scope SELECT aes_encrypt_mysql([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 166, line 167) (in query: SELECT aes_encrypt_mysql([NULL], '[HIDDEN]')) 2025.11.13 09:22:20.490125 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: Array(Nullable(Nothing)): In scope SELECT aes_encrypt_mysql([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:20.556158 [ 16233 ] {410d6606-5263-400a-9cfb-7fa4fdb3975e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'age'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT age([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 167, line 168) (in query: SELECT age([NULL], [NULL], [NULL]);) 2025.11.13 09:22:20.567270 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'age'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT age([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:21.011964 [ 16233 ] {1dd6ff33-da62-4675-96c2-bcbff8f2654d} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 168, line 169) (in query: SELECT aggThrow([NULL], [NULL], [NULL]);) 2025.11.13 09:22:21.034329 [ 16233 ] {} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) 2025.11.13 09:22:21.108085 [ 16233 ] {b7973873-cc4d-48b0-a8dd-fb50a57a0880} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT alphaTokens([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 169, line 170) (in query: SELECT alphaTokens([NULL], [NULL], [NULL]);) 2025.11.13 09:22:21.120397 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT alphaTokens([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:21.338039 [ 16233 ] {abca1a18-d6de-4931-a24b-6f8c07b76c3a} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 170, line 171) (in query: SELECT analysisOfVariance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:21.351005 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:21.354909 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 618.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:21.356050 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 618.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:21.580939 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 616.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:21.583076 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 616.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:21.583291 [ 16233 ] {270daf4b-7896-474d-9e5c-95ddaa0716d4} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function and: In scope SELECT [NULL] AND [NULL] AND [NULL]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 171, line 172) (in query: SELECT and([NULL], [NULL], [NULL]);) 2025.11.13 09:22:21.597030 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function and: In scope SELECT [NULL] AND [NULL] AND [NULL]. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:21.788446 [ 16233 ] {f1968842-7da2-4c89-9d07-e94ef41ecb83} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 172, line 173) (in query: SELECT anova([NULL], [NULL], [NULL]);) 2025.11.13 09:22:21.806102 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:21.948907 [ 16233 ] {73d793db-bf74-4dc2-a46e-55a59611ed61} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 173, line 174) (in query: SELECT any([NULL], [NULL], [NULL]);) 2025.11.13 09:22:21.960376 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:22.032119 [ 16233 ] {fb417d2a-a844-4f51-8093-72fd6203fce3} executeQuery: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 174, line 175) (in query: SELECT anyHeavy([NULL], [NULL], [NULL]);) 2025.11.13 09:22:22.155200 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:22.287347 [ 16233 ] {a5d66168-2f8d-4925-bd9c-8778c8f24692} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 175, line 176) (in query: SELECT anyLast([NULL], [NULL], [NULL]);) 2025.11.13 09:22:22.302463 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:22.372127 [ 16233 ] {73ebddb9-2d8a-434f-a1ec-a99993f3183a} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 176, line 177) (in query: SELECT anyLastRespectNulls([NULL], [NULL], [NULL]);) 2025.11.13 09:22:22.386429 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:22.512677 [ 16233 ] {2660a7cc-97ca-4650-8960-334a34d55cb3} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 177, line 178) (in query: SELECT anyLast_respect_nulls([NULL], [NULL], [NULL]);) 2025.11.13 09:22:22.533328 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:22.649294 [ 16233 ] {5c8c16ce-8600-4062-938d-810d9799ce6d} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 178, line 179) (in query: SELECT anyRespectNulls([NULL], [NULL], [NULL]);) 2025.11.13 09:22:22.680275 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:22.823353 [ 16233 ] {70d1ca97-bc25-4ba4-8ca2-7ae25312d0d3} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 179, line 180) (in query: SELECT anyValueRespectNulls([NULL], [NULL], [NULL]);) 2025.11.13 09:22:22.835772 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:22.892469 [ 16233 ] {63ee4ad7-6187-4de3-8b98-b02529cc01c8} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 180, line 181) (in query: SELECT any_respect_nulls([NULL], [NULL], [NULL]);) 2025.11.13 09:22:22.986570 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:23.132257 [ 16233 ] {1619c617-2b43-4acd-bb24-5c217b2abfe5} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 181, line 182) (in query: SELECT any_value([NULL], [NULL], [NULL]);) 2025.11.13 09:22:23.200744 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:23.244522 [ 16233 ] {2288bb77-51c6-4bdc-a69f-b646e7cdb73c} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 182, line 183) (in query: SELECT any_value_respect_nulls([NULL], [NULL], [NULL]);) 2025.11.13 09:22:23.255256 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:23.400154 [ 16233 ] {8eae2764-3b86-4bf0-a189-b97c737ac64b} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 183, line 184) (in query: SELECT appendTrailingCharIfAbsent([NULL], [NULL], [NULL]);) 2025.11.13 09:22:23.412880 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:23.567798 [ 16233 ] {eb54e686-f766-4fde-b2a8-b458c8e6d575} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 184, line 185) (in query: SELECT approx_top_count([NULL], [NULL], [NULL]);) 2025.11.13 09:22:23.579229 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:23.695333 [ 16233 ] {61e214bd-51ca-4507-a2d2-91fd94342ce8} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 185, line 186) (in query: SELECT approx_top_k([NULL], [NULL], [NULL]);) 2025.11.13 09:22:23.697134 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 621.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:23.698986 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 621.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:23.710365 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:24.080940 [ 16233 ] {aa0ec074-aeba-4ebd-b52d-d5f881c71e8f} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 186, line 187) (in query: SELECT approx_top_sum([NULL], [NULL], [NULL]);) 2025.11.13 09:22:24.093124 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:24.202341 [ 16233 ] {36cf3658-85c5-4adf-85c4-693bbf8fdd39} executeQuery: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 187, line 188) (in query: SELECT argMax([NULL], [NULL], [NULL]);) 2025.11.13 09:22:24.237385 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:24.286473 [ 16233 ] {ddfbacc2-b813-47fb-93c0-8ec8732d16ce} executeQuery: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 188, line 189) (in query: SELECT argMin([NULL], [NULL], [NULL]);) 2025.11.13 09:22:24.300430 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:24.559796 [ 16233 ] {fb325a68-bf46-47b2-b99c-f98adfb551f3} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nullable(Nothing), should be a number: In scope SELECT arrayAUC([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 190, line 191) (in query: SELECT arrayAUC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:24.572219 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nullable(Nothing), should be a number: In scope SELECT arrayAUC([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:24.644904 [ 16233 ] {4191dc91-c2a6-45df-af96-b1e5f300b3e2} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nullable(Nothing), should be a number: In scope SELECT arrayAUCPR([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 191, line 192) (in query: SELECT arrayAUCPR([NULL], [NULL], [NULL]);) 2025.11.13 09:22:24.657627 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nullable(Nothing), should be a number: In scope SELECT arrayAUCPR([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:24.719071 [ 16233 ] {dc7d03d5-a494-4a3b-80be-773a61e67bd2} executeQuery: Code: 43. DB::Exception: First argument for function arrayAll must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 192, line 193) (in query: SELECT arrayAll([NULL], [NULL], [NULL]);) 2025.11.13 09:22:24.729824 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayAll must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:24.788593 [ 16233 ] {249bafdc-300a-48c6-8432-e5d44f6ad425} executeQuery: Code: 43. DB::Exception: First argument for function arrayAvg must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayAvg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 193, line 194) (in query: SELECT arrayAvg([NULL], [NULL], [NULL]);) 2025.11.13 09:22:24.799193 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayAvg must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayAvg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:24.864062 [ 16233 ] {9f021ebe-902a-400f-9e20-d220253f1da9} executeQuery: Code: 43. DB::Exception: First argument for function arrayCompact must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCompact([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 194, line 195) (in query: SELECT arrayCompact([NULL], [NULL], [NULL]);) 2025.11.13 09:22:24.877374 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCompact must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCompact([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:25.193699 [ 16233 ] {0b9c7609-921f-4d08-8a01-2050530020ce} executeQuery: Code: 43. DB::Exception: First argument for function arrayCount must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCount([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 196, line 197) (in query: SELECT arrayCount([NULL], [NULL], [NULL]);) 2025.11.13 09:22:25.209894 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCount must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCount([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:25.368243 [ 16233 ] {8a8d53ea-def9-4422-8ee1-610e7bde9374} executeQuery: Code: 43. DB::Exception: First argument for function arrayCumSum must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCumSum([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 197, line 198) (in query: SELECT arrayCumSum([NULL], [NULL], [NULL]);) 2025.11.13 09:22:25.380694 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCumSum must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCumSum([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:25.488532 [ 16233 ] {56ad714d-e8db-4c3c-8128-5b7983959781} executeQuery: Code: 43. DB::Exception: First argument for function arrayCumSumNonNegative must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCumSumNonNegative([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 198, line 199) (in query: SELECT arrayCumSumNonNegative([NULL], [NULL], [NULL]);) 2025.11.13 09:22:25.499423 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCumSumNonNegative must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCumSumNonNegative([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:25.568207 [ 16233 ] {9677ba90-7dbd-40e3-88c3-62d81bf27fa7} executeQuery: Code: 43. DB::Exception: First argument for function arrayDifference must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayDifference([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 199, line 200) (in query: SELECT arrayDifference([NULL], [NULL], [NULL]);) 2025.11.13 09:22:25.579161 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayDifference must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayDifference([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:25.640642 [ 16233 ] {bedf8e7f-d4a0-4531-bbb1-d63b79dff46e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 200, line 201) (in query: SELECT arrayDistinct([NULL], [NULL], [NULL]);) 2025.11.13 09:22:25.651394 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:25.792156 [ 16233 ] {471babbd-65ec-4702-a088-a473d3d4e2c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 201, line 202) (in query: SELECT arrayDotProduct([NULL], [NULL], [NULL]);) 2025.11.13 09:22:25.804703 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:25.859166 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 635.94 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:25.861657 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 635.94 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:25.868837 [ 16233 ] {cad2ae6b-bdfa-4e2f-b3f8-5d4b7d9ebea5} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 202, line 203) (in query: SELECT arrayElement([NULL], [NULL], [NULL]);) 2025.11.13 09:22:25.881433 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:25.995376 [ 16233 ] {51f9ddbf-0b1a-47bf-81a9-35ad69459b2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 203, line 204) (in query: SELECT arrayElementOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:22:26.006323 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElementOrNull doesn't match: passed 3, should be 2: In scope SELECT arrayElementOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:26.068980 [ 16233 ] {24599c96-4160-4147-8038-665d06eb9833} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 204, line 205) (in query: SELECT arrayEnumerate([NULL], [NULL], [NULL]);) 2025.11.13 09:22:26.083195 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:26.502892 [ 18392 ] {b245063c-eec9-448b-8ac6-7effe68a6156} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: Int8: In scope SELECT arrayRandomSample([1, 2, 3], -5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34742) (query 1, line 1) (in query: SELECT arrayRandomSample([1, 2, 3], -5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e394520 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:22:26.510193 [ 18392 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: Int8: In scope SELECT arrayRandomSample([1, 2, 3], -5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e394520 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:22:26.692826 [ 16233 ] {38dafeb5-315a-4bac-8604-cdb905bbce8b} executeQuery: Code: 43. DB::Exception: First argument for function arrayExists must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayExists([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 209, line 210) (in query: SELECT arrayExists([NULL], [NULL], [NULL]);) 2025.11.13 09:22:26.803939 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayExists must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayExists([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:26.845794 [ 19620 ] {bdc44922-620d-44c7-abd5-6eb1b4377e28} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: String: In scope SELECT arrayRandomSample([1, 2, 3], 'a'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34838) (query 1, line 1) (in query: SELECT arrayRandomSample([1, 2, 3], 'a')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e394520 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:22:26.852771 [ 19620 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: String: In scope SELECT arrayRandomSample([1, 2, 3], 'a'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e394520 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:22:26.862303 [ 16233 ] {af466db6-1c99-442d-8afd-013831994a79} executeQuery: Code: 43. DB::Exception: First argument for function arrayFill must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFill([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 210, line 211) (in query: SELECT arrayFill([NULL], [NULL], [NULL]);) 2025.11.13 09:22:26.875735 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFill must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFill([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:26.933185 [ 16233 ] {014767f3-c603-4b0b-bd53-729c2e810e7d} executeQuery: Code: 43. DB::Exception: First argument for function arrayFilter must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFilter([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 211, line 212) (in query: SELECT arrayFilter([NULL], [NULL], [NULL]);) 2025.11.13 09:22:26.945706 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFilter must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFilter([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:27.009952 [ 16233 ] {b39fa647-285e-4e9d-a93c-85ad551e47f1} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirst must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirst([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 212, line 213) (in query: SELECT arrayFirst([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.022407 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirst must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirst([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:27.088670 [ 16233 ] {9785a7a5-fae2-4eda-b9f9-8b5b56eaebf3} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirstIndex must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirstIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 213, line 214) (in query: SELECT arrayFirstIndex([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.101222 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirstIndex must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirstIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:27.167429 [ 16233 ] {66cd1059-fffd-49d0-828a-40641f10185e} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirstOrNull must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirstOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 214, line 215) (in query: SELECT arrayFirstOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.180130 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirstOrNull must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirstOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:27.203186 [ 19620 ] {6f2c2403-5b6b-4f84-969b-1230c47d4e71} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: Float64: In scope SELECT arrayRandomSample([1, 2, 3], 1.5). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34866) (query 1, line 1) (in query: SELECT arrayRandomSample([1, 2, 3], 1.5)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e394520 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:22:27.211623 [ 19620 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: Float64: In scope SELECT arrayRandomSample([1, 2, 3], 1.5). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionArrayRandomSample::getReturnTypeImpl(std::vector> const&) const @ 0x000000001e394520 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:22:27.240479 [ 16233 ] {654ab15b-8e18-498c-800e-d3a51a76e141} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 215, line 216) (in query: SELECT arrayFlatten([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.253314 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:27.321353 [ 16233 ] {58479d45-79d3-4e0c-86ee-4daef073ffa7} executeQuery: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 216, line 217) (in query: SELECT arrayFold([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.335519 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:27.479239 [ 16233 ] {03882488-7fdf-48da-90cb-8202cd4f8c77} executeQuery: Code: 44. DB::Exception: Nullable(Nothing) cannot be inside Nullable column: In scope SELECT arrayIntersect([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 217, line 218) (in query: SELECT arrayIntersect([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.496059 [ 16233 ] {} TCPHandler: Code: 44. DB::Exception: Nullable(Nothing) cannot be inside Nullable column: In scope SELECT arrayIntersect([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) 2025.11.13 09:22:27.546079 [ 16233 ] {c6708955-d047-4953-a363-4e2fb98d0011} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 218, line 219) (in query: SELECT arrayJaccardIndex([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.559074 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:27.615713 [ 16233 ] {0d696fb8-1b29-4db3-bd7c-1e6994a6e862} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 219, line 220) (in query: SELECT arrayJoin([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.636005 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:27.743518 [ 16233 ] {45cd4c99-dc14-4acf-b986-3ee2c7741050} executeQuery: Code: 43. DB::Exception: First argument for function arrayLast must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLast([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 220, line 221) (in query: SELECT arrayLast([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.755410 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLast must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLast([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:27.812765 [ 16233 ] {65b5cada-0ecc-43bb-a06e-679673106922} executeQuery: Code: 43. DB::Exception: First argument for function arrayLastIndex must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLastIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 221, line 222) (in query: SELECT arrayLastIndex([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.823997 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLastIndex must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLastIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:27.829786 [ 3727 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_116_8} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 669.91 MiB (attempt to allocate chunk of 1.29 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_111_7/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 1 with max_rows_to_read = 8848): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:27.831628 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_116_8}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 669.91 MiB (attempt to allocate chunk of 1.29 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_111_7/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 1 with max_rows_to_read = 8848): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:27.910676 [ 16233 ] {6f69961f-781d-4d3c-9050-744ec7a38cb1} executeQuery: Code: 43. DB::Exception: First argument for function arrayLastOrNull must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLastOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 222, line 223) (in query: SELECT arrayLastOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:22:27.924667 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLastOrNull must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLastOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:27.931329 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 669.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:27.933242 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 669.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:28.067790 [ 16233 ] {f3c2f949-2680-4f86-acfb-0db01b4a5fb8} executeQuery: Code: 43. DB::Exception: First argument for function arrayMap must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMap([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 223, line 224) (in query: SELECT arrayMap([NULL], [NULL], [NULL]);) 2025.11.13 09:22:28.079952 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMap must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMap([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:28.196172 [ 16233 ] {6212925f-91e4-426a-ba8b-e69150a6fd97} executeQuery: Code: 43. DB::Exception: First argument for function arrayMax must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 224, line 225) (in query: SELECT arrayMax([NULL], [NULL], [NULL]);) 2025.11.13 09:22:28.207895 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMax must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:28.273479 [ 16233 ] {d9fb3c83-f53c-4e56-94b5-70bec40ca678} executeQuery: Code: 43. DB::Exception: First argument for function arrayMin must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMin([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 225, line 226) (in query: SELECT arrayMin([NULL], [NULL], [NULL]);) 2025.11.13 09:22:28.289029 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMin must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMin([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:28.402861 [ 16233 ] {3ae9c931-b135-46f3-8417-938c5107ecde} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 3, should be 2: In scope SELECT arrayNormalizedGini([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 226, line 227) (in query: SELECT arrayNormalizedGini([NULL], [NULL], [NULL]);) 2025.11.13 09:22:28.418137 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayNormalizedGini doesn't match: passed 3, should be 2: In scope SELECT arrayNormalizedGini([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:28.482029 [ 16233 ] {a944c5f2-dc53-4bab-8ea7-2675d257316f} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nullable(Nothing), should be a number: In scope SELECT arrayPRAUC([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 227, line 228) (in query: SELECT arrayPRAUC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:28.493994 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayAUCPR is of type Nullable(Nothing), should be a number: In scope SELECT arrayPRAUC([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:28.559660 [ 16233 ] {62f4eb3e-29d4-4aaf-af31-28f14238e825} executeQuery: Code: 43. DB::Exception: First argument for function arrayPartialReverseSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayPartialReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 228, line 229) (in query: SELECT arrayPartialReverseSort([NULL], [NULL], [NULL]);) 2025.11.13 09:22:28.571519 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPartialReverseSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayPartialReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:28.780378 [ 16233 ] {50ed505f-478c-44f3-b547-35972fded135} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of arguments of function arrayPartialShuffle (must be UInt or Int): In scope SELECT arrayPartialShuffle([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 229, line 230) (in query: SELECT arrayPartialShuffle([NULL], [NULL], [NULL]);) 2025.11.13 09:22:28.791989 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of arguments of function arrayPartialShuffle (must be UInt or Int): In scope SELECT arrayPartialShuffle([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:28.855128 [ 16233 ] {2d5f171c-262c-4e60-8d41-93902c3be817} executeQuery: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayPartialSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 230, line 231) (in query: SELECT arrayPartialSort([NULL], [NULL], [NULL]);) 2025.11.13 09:22:28.868905 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayPartialSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:28.931616 [ 16233 ] {cb84a7ef-0076-4f90-88c4-b19cb2e77ccb} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 231, line 232) (in query: SELECT arrayPopBack([NULL], [NULL], [NULL]);) 2025.11.13 09:22:28.942648 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:29.075682 [ 16233 ] {bada4a03-ebc1-43de-9481-f4d07f000161} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 232, line 233) (in query: SELECT arrayPopFront([NULL], [NULL], [NULL]);) 2025.11.13 09:22:29.090573 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:29.247521 [ 16233 ] {be2699bc-f12f-4940-bd5d-a0cac7884ad8} executeQuery: Code: 43. DB::Exception: First argument for function arrayProduct must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayProduct([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 233, line 234) (in query: SELECT arrayProduct([NULL], [NULL], [NULL]);) 2025.11.13 09:22:29.260500 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayProduct must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayProduct([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:29.323050 [ 16233 ] {63afddd9-d640-4941-9f1a-8acdea7daa06} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 234, line 235) (in query: SELECT arrayPushBack([NULL], [NULL], [NULL]);) 2025.11.13 09:22:29.333447 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:29.418036 [ 16233 ] {d8d4bbca-af78-4365-afd6-9a81cf494fc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 235, line 236) (in query: SELECT arrayPushFront([NULL], [NULL], [NULL]);) 2025.11.13 09:22:29.529220 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:29.594351 [ 16233 ] {8e8341bd-6370-4e1f-a889-46ae93efbcf0} executeQuery: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nullable(Nothing), should be a number: In scope SELECT arrayROCAUC([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 236, line 237) (in query: SELECT arrayROCAUC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:29.604915 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 610.86 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:29.606690 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 610.86 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:29.607122 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument (arr_scores) for function arrayROCAUC is of type Nullable(Nothing), should be a number: In scope SELECT arrayROCAUC([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:29.668204 [ 16233 ] {1663cbe1-10b0-4c2a-982f-c8305b7cc985} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 237, line 238) (in query: SELECT arrayRandomSample([NULL], [NULL], [NULL]);) 2025.11.13 09:22:29.679225 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:29.866427 [ 16233 ] {70860b92-ef4c-4dab-9b35-c391b98f385d} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 238, line 239) (in query: SELECT arrayReduce([NULL], [NULL], [NULL]);) 2025.11.13 09:22:29.878950 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:29.886507 [ 10170 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:22:29.887630 [ 10170 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:29.888503 [ 3736 ] {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_114_23} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 512.92 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:29.890322 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_114_23}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 512.92 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:29.951377 [ 16233 ] {d274cada-b4fc-481c-982f-652dd78b1e3c} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduceInRanges must be constant string: name of aggregate function.: In scope SELECT arrayReduceInRanges([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 239, line 240) (in query: SELECT arrayReduceInRanges([NULL], [NULL], [NULL]);) 2025.11.13 09:22:29.962329 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduceInRanges must be constant string: name of aggregate function.: In scope SELECT arrayReduceInRanges([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:30.024817 [ 16233 ] {9450ea4e-0dab-497a-8efd-4560aeae0f0a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT arrayResize([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 240, line 241) (in query: SELECT arrayResize([NULL], [NULL], [NULL]);) 2025.11.13 09:22:30.036470 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT arrayResize([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:30.237591 [ 16233 ] {9ba9da37-b245-4676-8ea5-04f320444796} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 241, line 242) (in query: SELECT arrayReverse([NULL], [NULL], [NULL]);) 2025.11.13 09:22:30.251158 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:30.313699 [ 16233 ] {074a7ed4-1700-4b65-b18c-1dbe162da6f2} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseFill must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseFill([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 242, line 243) (in query: SELECT arrayReverseFill([NULL], [NULL], [NULL]);) 2025.11.13 09:22:30.326135 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseFill must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseFill([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:30.389134 [ 16233 ] {fba27682-f8c4-46d3-bd6a-b0b06e1796ee} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 243, line 244) (in query: SELECT arrayReverseSort([NULL], [NULL], [NULL]);) 2025.11.13 09:22:30.400301 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:30.458661 [ 16233 ] {f55d8061-b72d-4c93-927f-fd66375fd44a} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseSplit must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseSplit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 244, line 245) (in query: SELECT arrayReverseSplit([NULL], [NULL], [NULL]);) 2025.11.13 09:22:30.469797 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseSplit must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseSplit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:30.557780 [ 16233 ] {0f472014-391d-4e6b-a16a-36d6e88136e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 245, line 246) (in query: SELECT arrayRotateLeft([NULL], [NULL], [NULL]);) 2025.11.13 09:22:30.571057 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:30.635581 [ 16233 ] {028a15c9-80f4-426b-bf68-d25280bd9b25} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 246, line 247) (in query: SELECT arrayRotateRight([NULL], [NULL], [NULL]);) 2025.11.13 09:22:30.648106 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:30.710239 [ 16233 ] {723fe9d7-ab6b-4a47-96d3-85395522a00b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function arrayShiftLeft, expected Native Integer: In scope SELECT arrayShiftLeft([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 247, line 248) (in query: SELECT arrayShiftLeft([NULL], [NULL], [NULL]);) 2025.11.13 09:22:30.721826 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function arrayShiftLeft, expected Native Integer: In scope SELECT arrayShiftLeft([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:30.767364 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 525.83 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:30.820779 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 525.83 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:30.854104 [ 17226 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 512.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:30.855122 [ 17226 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 512.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:30.862795 [ 16233 ] {cd161e36-f2bc-4d9f-b925-d35c501641ef} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function arrayShiftRight, expected Native Integer: In scope SELECT arrayShiftRight([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 248, line 249) (in query: SELECT arrayShiftRight([NULL], [NULL], [NULL]);) 2025.11.13 09:22:30.874376 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function arrayShiftRight, expected Native Integer: In scope SELECT arrayShiftRight([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:30.932397 [ 16233 ] {bf1bbcd3-4467-4dc6-9e64-f5e37d314ee4} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 249, line 250) (in query: SELECT arrayShingles([NULL], [NULL], [NULL]);) 2025.11.13 09:22:30.943484 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:31.049479 [ 16233 ] {df545a71-2fdc-49c7-8e15-4a5495f954fc} executeQuery: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 250, line 251) (in query: SELECT arrayShuffle([NULL], [NULL], [NULL]);) 2025.11.13 09:22:31.063218 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:31.123219 [ 16233 ] {9d485763-39e3-45e3-83a0-6a199a863094} executeQuery: Code: 43. DB::Exception: Argument 1 for function arraySlice must be integer but it has type Array(Nullable(Nothing)).: In scope SELECT arraySlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 251, line 252) (in query: SELECT arraySlice([NULL], [NULL], [NULL]);) 2025.11.13 09:22:31.134821 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 for function arraySlice must be integer but it has type Array(Nullable(Nothing)).: In scope SELECT arraySlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:31.204060 [ 16233 ] {e4d506ab-df4d-49b6-a6e3-af646835260c} executeQuery: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 252, line 253) (in query: SELECT arraySort([NULL], [NULL], [NULL]);) 2025.11.13 09:22:31.218624 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:31.291357 [ 16233 ] {f3e5ef15-1348-43f8-a0bb-c60c62bd0bdb} executeQuery: Code: 43. DB::Exception: First argument for function arraySplit must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySplit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 253, line 254) (in query: SELECT arraySplit([NULL], [NULL], [NULL]);) 2025.11.13 09:22:31.302783 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arraySplit must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySplit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:31.366004 [ 16233 ] {a3da9707-90eb-4406-9e60-89861934b6ff} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT arrayStringConcat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 254, line 255) (in query: SELECT arrayStringConcat([NULL], [NULL], [NULL]);) 2025.11.13 09:22:31.378625 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT arrayStringConcat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:31.479527 [ 19620 ] {46f8c32b-793f-4f89-b075-19055acb9709} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 512.87 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION modulo(rand() :: 4, 2600000_UInt32 :: 3) -> modulo(rand(), 2600000_UInt32) UInt32 : 1'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34900) (comment: 03093_bug37909_query_does_not_finish.sql) (query 1, line 1) (in query: -- Bug 37909 SELECT v_date AS vDate, round(sum(v_share)) AS v_sum FROM ( WITH ( SELECT rand() % 10000 ) AS dummy_1, ( SELECT rand() % 10000 ) AS dummy_2, ( SELECT rand() % 10000 ) AS dummy_3, _v AS ( SELECT xxHash64(rand()) % 100000 AS d_id, toDate(parseDateTimeBestEffort('2022-01-01') + (rand() % 2600000)) AS v_date FROM numbers(1000000) ORDER BY d_id ASC ), _i AS ( SELECT xxHash64(rand()) % 40000 AS d_id FROM numbers(1000000) ), not_i AS ( SELECT NULL AS v_date, d_id, 0 AS v_share FROM _i LIMIT 100 ) SELECT * FROM ( SELECT d_id, v_date, v_share FROM not_i UNION ALL SELECT d_id, v_date, 1 AS v_share FROM ( SELECT d_id, arrayJoin(groupArray(v_date)) AS v_date FROM ( SELECT v_date, d_id FROM _v UNION ALL SELECT NULL AS v_date, d_id FROM _i ) GROUP BY d_id ) ) WHERE (v_date >= '2022-05-08') AND (v_date <= '2022-06-07') ) /* WHERE (v_date >= '2022-05-08') AND (v_date <= '2022-06-07') placing condition has same effect */ GROUP BY vDate ORDER BY vDate ASC SETTINGS enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c115fc 12. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000015644f9e 13. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000015644190 14. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001563e779 15. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000155e03fd 16. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000155d6bb2 17. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000155d116d 18. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000155ced6d 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:22:31.539356 [ 16233 ] {30e2d134-edd9-43a4-9b0a-18a19059dd6a} executeQuery: Code: 43. DB::Exception: First argument for function arraySum must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySum([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 255, line 256) (in query: SELECT arraySum([NULL], [NULL], [NULL]);) 2025.11.13 09:22:31.551193 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function arraySum must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySum([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:31.626036 [ 16233 ] {e1bc2969-0d2c-4050-8aa6-cc3f6ba7a6d5} executeQuery: Code: 44. DB::Exception: Nullable(Nothing) cannot be inside Nullable column: In scope SELECT arraySymmetricDifference([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 256, line 257) (in query: SELECT arraySymmetricDifference([NULL], [NULL], [NULL]);) 2025.11.13 09:22:31.641266 [ 16233 ] {} TCPHandler: Code: 44. DB::Exception: Nullable(Nothing) cannot be inside Nullable column: In scope SELECT arraySymmetricDifference([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) 2025.11.13 09:22:31.647703 [ 19620 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 512.87 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION modulo(rand() :: 4, 2600000_UInt32 :: 3) -> modulo(rand(), 2600000_UInt32) UInt32 : 1'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c115fc 12. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000015644f9e 13. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000015644190 14. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001563e779 15. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000155e03fd 16. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000155d6bb2 17. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000155d116d 18. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000155ced6d 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:22:31.714719 [ 16233 ] {2017dbc3-b395-4bac-bc87-72e5f08e9bf1} executeQuery: Code: 44. DB::Exception: Nullable(Nothing) cannot be inside Nullable column: In scope SELECT arrayUnion([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 257, line 258) (in query: SELECT arrayUnion([NULL], [NULL], [NULL]);) 2025.11.13 09:22:31.726662 [ 16233 ] {} TCPHandler: Code: 44. DB::Exception: Nullable(Nothing) cannot be inside Nullable column: In scope SELECT arrayUnion([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) 2025.11.13 09:22:32.245159 [ 16233 ] {9bc54f57-865b-45da-866c-48b1b3baab90} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 259, line 260) (in query: SELECT arrayWithConstant([NULL], [NULL], [NULL]);) 2025.11.13 09:22:32.262111 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:32.652152 [ 16233 ] {e8cac5ff-db37-4e7d-bc5d-f9ca39cbdb61} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 262, line 263) (in query: SELECT array_agg([NULL], [NULL], [NULL]);) 2025.11.13 09:22:32.665431 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:32.708510 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 619.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:32.710622 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 619.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:32.962214 [ 16233 ] {0e926985-699d-47bc-b306-69b4617bcb60} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 264, line 265) (in query: SELECT ascii([NULL], [NULL], [NULL]);) 2025.11.13 09:22:33.065623 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:33.119365 [ 16233 ] {a48db7be-9c92-4ff1-8c8a-68e71e3978c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 265, line 266) (in query: SELECT asin([NULL], [NULL], [NULL]);) 2025.11.13 09:22:33.131522 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:33.266215 [ 16233 ] {4059893f-e0a5-40cf-9e92-5ec9d4192816} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 266, line 267) (in query: SELECT asinh([NULL], [NULL], [NULL]);) 2025.11.13 09:22:33.377951 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:33.491951 [ 16233 ] {1406d1b1-0363-41e0-87cf-83285c6e40fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 267, line 268) (in query: SELECT assumeNotNull([NULL], [NULL], [NULL]);) 2025.11.13 09:22:33.503101 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:33.563705 [ 16233 ] {38300f4f-9a2b-4a8e-b60a-2526ae3ee659} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 268, line 269) (in query: SELECT atan([NULL], [NULL], [NULL]);) 2025.11.13 09:22:33.574337 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:33.641142 [ 16233 ] {aa64d1d6-ae79-48f1-ae5d-983e9c537db8} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 269, line 270) (in query: SELECT atan2([NULL], [NULL], [NULL]);) 2025.11.13 09:22:33.654615 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:33.717993 [ 16233 ] {525f40a1-7132-48b5-9caa-63350839f57a} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 270, line 271) (in query: SELECT atanh([NULL], [NULL], [NULL]);) 2025.11.13 09:22:33.731368 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:33.843130 [ 16233 ] {d7f75731-3b6a-413e-8daf-408e26521066} executeQuery: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authUser([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 271, line 272) (in query: SELECT authUser([NULL], [NULL], [NULL]);) 2025.11.13 09:22:33.855065 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authUser([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:33.922110 [ 16233 ] {d3a31231-7d16-47a0-a14b-60dc503cb0ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authenticatedUser([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 272, line 273) (in query: SELECT authenticatedUser([NULL], [NULL], [NULL]);) 2025.11.13 09:22:33.932969 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function authenticatedUser doesn't match: passed 3, should be 0: In scope SELECT authenticatedUser([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:34.000194 [ 16233 ] {1c826d5a-4faa-4bf2-b052-bb0761d230a4} executeQuery: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 273, line 274) (in query: SELECT avg([NULL], [NULL], [NULL]);) 2025.11.13 09:22:34.014722 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:34.072158 [ 16233 ] {07f811a0-8748-41c9-8887-a160f500a1ca} executeQuery: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 274, line 275) (in query: SELECT avgWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:22:34.156149 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:34.223833 [ 16233 ] {e90f1701-184a-40e9-b81b-12f0c2b9567a} executeQuery: Code: 43. DB::Exception: All arguments for function bar must be numeric.: In scope SELECT bar([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 275, line 276) (in query: SELECT bar([NULL], [NULL], [NULL]);) 2025.11.13 09:22:34.234738 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: All arguments for function bar must be numeric.: In scope SELECT bar([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:34.366177 [ 16233 ] {ba3a572c-1c37-436b-b13a-0a4c86a480b3} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 276, line 277) (in query: SELECT base58Decode([NULL], [NULL], [NULL]);) 2025.11.13 09:22:34.380440 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:34.428801 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 541.48 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:34.430615 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 541.48 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:34.446043 [ 16233 ] {a4bf3082-c12c-4261-a03a-6cd8ced48e7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 277, line 278) (in query: SELECT base58Encode([NULL], [NULL], [NULL]);) 2025.11.13 09:22:34.451830 [ 18403 ] {ca0feb66-08ac-496b-94fc-b7c89ba0ee4f} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 511.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36374) (comment: 00878_join_unexpected_results.sql) (query 5, line 7) (in query: insert into t values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:22:34.463704 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:34.468834 [ 4170 ] {1c3ef2c9-3984-4a6b-8b85-8b8a91d909a1} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 512.46 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34918) (comment: 03203_fill_missed_subcolumns.sql) (query 21, line 39) (in query: INSERT INTO t_missed_subcolumns VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:22:34.469175 [ 18403 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 511.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:22:34.469712 [ 10170 ] {6822c7b4-0b80-42b2-b23f-07aa6997c68d} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 511.44 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36388) (comment: 02766_prql.sh) (query 3, line 14) (in query: INSERT INTO aboba (user_id, message, creation_date, metric) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:22:34.483893 [ 10170 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 511.44 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:22:34.490050 [ 4170 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 512.46 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:22:34.552415 [ 16233 ] {1ca4d8d7-97f4-4fe6-9f1e-fb22c664ddbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 278, line 279) (in query: SELECT base64Decode([NULL], [NULL], [NULL]);) 2025.11.13 09:22:34.567236 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:34.643364 [ 16233 ] {7d8e97ba-6f35-43eb-8c80-d2ba7a942a17} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 279, line 280) (in query: SELECT base64Encode([NULL], [NULL], [NULL]);) 2025.11.13 09:22:34.668909 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:34.760234 [ 16233 ] {8c06e695-8c0c-4594-a361-66ae07cbec46} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 280, line 281) (in query: SELECT base64URLDecode([NULL], [NULL], [NULL]);) 2025.11.13 09:22:34.772803 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:34.830075 [ 16233 ] {cbbe9cc9-8c39-42ad-8ab6-aa1bb70e004f} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 281, line 282) (in query: SELECT base64URLEncode([NULL], [NULL], [NULL]);) 2025.11.13 09:22:34.841779 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:34.980248 [ 16233 ] {03658ecd-50da-4fb7-8c07-9f68c2a086c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 282, line 283) (in query: SELECT basename([NULL], [NULL], [NULL]);) 2025.11.13 09:22:34.994243 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:35.050676 [ 16233 ] {d0aa7565-b6b3-4bba-8097-191105ee0b29} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 283, line 284) (in query: SELECT bin([NULL], [NULL], [NULL]);) 2025.11.13 09:22:35.075981 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:35.140780 [ 16233 ] {4997caba-f13f-4681-be08-49e2e511e593} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 284, line 285) (in query: SELECT bitAnd([NULL], [NULL], [NULL]);) 2025.11.13 09:22:35.152768 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:35.219318 [ 16233 ] {59bef572-0786-4e4b-a11b-5cdf1e60d928} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 285, line 286) (in query: SELECT bitCount([NULL], [NULL], [NULL]);) 2025.11.13 09:22:35.233653 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:35.298498 [ 3729 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_82_14} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 528.03 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column ProfileEvent_MergerMutatorPartsInRangesForMergeCount): (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_78_78_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 22): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7ac08c 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:35.300507 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_82_14}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 528.03 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column ProfileEvent_MergerMutatorPartsInRangesForMergeCount): (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_78_78_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 22): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7ac08c 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:35.409974 [ 16233 ] {a1cca90d-b965-4f7c-8a3b-e6fe82a06da7} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 286, line 287) (in query: SELECT bitHammingDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:35.422079 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:35.480570 [ 16233 ] {e0454108-6ea9-4458-841c-db3e5663a38b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 287, line 288) (in query: SELECT bitNot([NULL], [NULL], [NULL]);) 2025.11.13 09:22:35.491714 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:35.550457 [ 16233 ] {d089e9fc-ec5f-4181-9264-d7ad01e4b3ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 288, line 289) (in query: SELECT bitOr([NULL], [NULL], [NULL]);) 2025.11.13 09:22:35.561467 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:35.706986 [ 16233 ] {28df283f-6070-4c15-bb21-40328920f957} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 289, line 290) (in query: SELECT bitPositionsToArray([NULL], [NULL], [NULL]);) 2025.11.13 09:22:35.718748 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:35.786889 [ 16233 ] {e5f3c9b2-aac5-4b4d-a332-5f7acaff4cd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 290, line 291) (in query: SELECT bitRotateLeft([NULL], [NULL], [NULL]);) 2025.11.13 09:22:35.810749 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:35.908345 [ 16233 ] {1dab217a-51aa-41d0-bac0-e90e326795d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 291, line 292) (in query: SELECT bitRotateRight([NULL], [NULL], [NULL]);) 2025.11.13 09:22:35.920491 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:35.981669 [ 16233 ] {d64b76a6-d2fb-4a58-9232-ac44b7f5e2d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 292, line 293) (in query: SELECT bitShiftLeft([NULL], [NULL], [NULL]);) 2025.11.13 09:22:36.071837 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:36.204446 [ 16233 ] {c947bcff-3686-426b-8467-eb9cd4489650} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 293, line 294) (in query: SELECT bitShiftRight([NULL], [NULL], [NULL]);) 2025.11.13 09:22:36.219543 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:36.278922 [ 16233 ] {a8ec5bd4-9a3b-4d6e-96b6-77fcefa9547e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT bitSlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 294, line 295) (in query: SELECT bitSlice([NULL], [NULL], [NULL]);) 2025.11.13 09:22:36.292228 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT bitSlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:36.530634 [ 16233 ] {428815e7-3a06-46a6-9ed7-dfd5fd03cfa5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 295, line 296) (in query: SELECT bitTest([NULL], [NULL], [NULL]);) 2025.11.13 09:22:36.541898 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:36.730984 [ 16233 ] {242ac1f3-ce18-4b44-9259-ce964f02ff57} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function bitTestAll: In scope SELECT bitTestAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 296, line 297) (in query: SELECT bitTestAll([NULL], [NULL], [NULL]);) 2025.11.13 09:22:36.742393 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function bitTestAll: In scope SELECT bitTestAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:36.750607 [ 19499 ] {47834add-3740-48f6-9740-2158d8a623bd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34788) (query 8, line 21) (in query: select count() from system.query_log where query like 'select \'01547_query_log_current_database%' and current_database = currentDatabase() and event_date >= yesterday();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:36.805178 [ 16233 ] {0639f1b4-7427-481e-8553-c1824137b6e0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function bitTestAny: In scope SELECT bitTestAny([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 297, line 298) (in query: SELECT bitTestAny([NULL], [NULL], [NULL]);) 2025.11.13 09:22:36.815673 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function bitTestAny: In scope SELECT bitTestAny([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:36.904622 [ 19499 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:22:37.060886 [ 16233 ] {387aea38-cd45-4d63-bca8-6f45abfb0d14} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 298, line 299) (in query: SELECT bitXor([NULL], [NULL], [NULL]);) 2025.11.13 09:22:37.079643 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:37.115123 [ 3270 ] {} test_15.partitioned_table (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:22:37.116654 [ 3512 ] {} test_7.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:22:37.118389 [ 3489 ] {} test_15.data_rep_02228 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:22:37.121109 [ 3246 ] {} test_nu5td7bc.wrong_metadata (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:22:37.122772 [ 3532 ] {} test_1.t_mutations_nondeterministic (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:22:37.124282 [ 3272 ] {} test_15.table_3 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:22:37.125882 [ 3343 ] {} test_7.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:22:37.126993 [ 3235 ] {} test_9.join_inner_table (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:22:37.129853 [ 3459 ] {} test_9.test_r1 (d15ac53d-69dd-407f-ba26-4e7c6429e4ff): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003d0a7a6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160d5e 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1565: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003d16fe74 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1358: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff8840 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:301: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff78a0 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:375: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9ec7 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:337: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9bca 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x000000003a2ef3f9 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3830: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000038a68019 11. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:423: void std::__function::__policy_invoker::__call_impl[abi:ne190107], String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&)::$_2, void ()>>(std::__function::__policy_storage const*) @ 0x0000000038c91f9f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:37.232053 [ 17390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 656.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:37.233079 [ 17390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 656.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:37.235630 [ 16233 ] {955bb4f2-dfd2-433e-ae1f-302b65777dcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 299, line 300) (in query: SELECT bitmapAnd([NULL], [NULL], [NULL]);) 2025.11.13 09:22:37.250023 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:37.405088 [ 16233 ] {015a932f-fd00-4024-8021-e8030a002331} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 300, line 301) (in query: SELECT bitmapAndCardinality([NULL], [NULL], [NULL]);) 2025.11.13 09:22:37.437417 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:37.453336 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 656.39 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:37.457388 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 656.39 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:37.504724 [ 16233 ] {fe45fc90-8c57-4c42-a766-00a76a3c28c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 301, line 302) (in query: SELECT bitmapAndnot([NULL], [NULL], [NULL]);) 2025.11.13 09:22:37.515543 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:37.575547 [ 16233 ] {6ab44a8b-f758-4e22-a8fd-7554e2ce921c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 302, line 303) (in query: SELECT bitmapAndnotCardinality([NULL], [NULL], [NULL]);) 2025.11.13 09:22:37.589427 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:37.649650 [ 16233 ] {2923dca3-2b59-46a0-a648-1e6b900f4b55} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 303, line 304) (in query: SELECT bitmapBuild([NULL], [NULL], [NULL]);) 2025.11.13 09:22:37.660467 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:37.723483 [ 16233 ] {b6590bfb-4915-42d3-8906-1d11f410a81b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 304, line 305) (in query: SELECT bitmapCardinality([NULL], [NULL], [NULL]);) 2025.11.13 09:22:37.735193 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:37.800038 [ 16233 ] {60b3d352-7d33-44e5-a48d-fc4a0975b3d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 305, line 306) (in query: SELECT bitmapContains([NULL], [NULL], [NULL]);) 2025.11.13 09:22:37.811947 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:37.823476 [ 10170 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:37.886236 [ 3596 ] {} test_7.rmt1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Session expired (fault injected on send). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003a3dfd6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003d179be4 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1789: Coordination::ZooKeeper::maybeInjectSendFault() @ 0x000000003d1613c2 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1297: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x000000003d160a3b 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1565: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x000000003d16fe74 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:1358: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff8840 8. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:301: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff78a0 9. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:375: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000003cff9ec7 10. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:348: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000003cff9150 11. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:547: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000003a25536c 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:477: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x000000003a242ff6 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:194: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a234588 14. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a230a02 15. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a25a2bf 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:37.950550 [ 16233 ] {ce3b22d0-c224-4e3d-91be-da90c307fb19} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 306, line 307) (in query: SELECT bitmapHasAll([NULL], [NULL], [NULL]);) 2025.11.13 09:22:37.962816 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:38.025070 [ 16233 ] {924ffa2b-65d7-40fb-a558-164ce1e8271b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 307, line 308) (in query: SELECT bitmapHasAny([NULL], [NULL], [NULL]);) 2025.11.13 09:22:38.105157 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:38.164628 [ 16233 ] {61e2a42a-6d8e-410c-94e7-c19473b2e409} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 308, line 309) (in query: SELECT bitmapMax([NULL], [NULL], [NULL]);) 2025.11.13 09:22:38.175799 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:38.238705 [ 16233 ] {ee32721e-f272-4137-9652-8f8b57203e28} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 309, line 310) (in query: SELECT bitmapMin([NULL], [NULL], [NULL]);) 2025.11.13 09:22:38.250149 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:38.429518 [ 16233 ] {1a5d84f6-768b-4ead-9df4-ae4918c1dcad} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 310, line 311) (in query: SELECT bitmapOr([NULL], [NULL], [NULL]);) 2025.11.13 09:22:38.444979 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:38.583986 [ 16233 ] {5af6017b-0aea-4a41-8a98-50ddadcb8533} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 311, line 312) (in query: SELECT bitmapOrCardinality([NULL], [NULL], [NULL]);) 2025.11.13 09:22:38.592471 [ 18403 ] {220e527c-a4c6-49ea-81d0-4a292b6d43f2} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 654.50 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36470) (comment: 02461_prewhere_row_level_policy_lightweight_delete.gen.sql) (query 4, line 12) (in query: -- Insert some data to have 110K rows in the range 2022-08-10 .. 2022-08-20 and some more rows before and after that range insert into url_na_log select 209, ('2022-08-09'::Date + INTERVAL intDiv(number,10000) DAY) from numbers(130000) SETTINGS max_insert_block_size=200000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:22:38.596795 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:38.605489 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 532.19 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:38.683176 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 532.19 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:38.690425 [ 18403 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 654.50 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:38.726563 [ 16233 ] {bf9135f2-f07a-4bdf-8ab2-e1e88f121a31} executeQuery: Code: 43. DB::Exception: First argument for function bitmapSubsetInRange must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapSubsetInRange([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 312, line 313) (in query: SELECT bitmapSubsetInRange([NULL], [NULL], [NULL]);) 2025.11.13 09:22:38.744305 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapSubsetInRange must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapSubsetInRange([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:38.803920 [ 16233 ] {8c04c010-e119-45b5-8128-66558a6486de} executeQuery: Code: 43. DB::Exception: First argument for function bitmapSubsetLimit must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapSubsetLimit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 313, line 314) (in query: SELECT bitmapSubsetLimit([NULL], [NULL], [NULL]);) 2025.11.13 09:22:38.814883 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapSubsetLimit must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapSubsetLimit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:38.882670 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 493.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:38.883847 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 493.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:39.017098 [ 16233 ] {5756564d-acfe-4664-b7b5-6d0f0b500681} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 314, line 315) (in query: SELECT bitmapToArray([NULL], [NULL], [NULL]);) 2025.11.13 09:22:39.029342 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:39.096951 [ 16233 ] {0eb90b18-33ad-4b29-9294-a6dbd66c8b2f} executeQuery: Code: 43. DB::Exception: First argument for function bitmapTransform must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapTransform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 315, line 316) (in query: SELECT bitmapTransform([NULL], [NULL], [NULL]);) 2025.11.13 09:22:39.108303 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapTransform must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapTransform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:39.237554 [ 16233 ] {1d089e44-f32d-435c-bf11-ec93a021dfde} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 316, line 317) (in query: SELECT bitmapXor([NULL], [NULL], [NULL]);) 2025.11.13 09:22:39.286826 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:39.362408 [ 16233 ] {a2d62e8a-aa35-4607-a49d-8ebe766256f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 317, line 318) (in query: SELECT bitmapXorCardinality([NULL], [NULL], [NULL]);) 2025.11.13 09:22:39.374453 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:39.455092 [ 18403 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 492.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:39.456140 [ 18403 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 492.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:39.543455 [ 16233 ] {ba3049eb-d394-4c69-8414-fc7415a5d180} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 318, line 319) (in query: SELECT bitmaskToArray([NULL], [NULL], [NULL]);) 2025.11.13 09:22:39.555312 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:39.617322 [ 16233 ] {e7e35371-34b6-4c0e-a9ba-e748cfeb9306} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 319, line 320) (in query: SELECT bitmaskToList([NULL], [NULL], [NULL]);) 2025.11.13 09:22:39.628281 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:39.740659 [ 16233 ] {f0769b3f-020c-4745-baa8-31c15d73cab2} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 320, line 321) (in query: SELECT blockNumber([NULL], [NULL], [NULL]);) 2025.11.13 09:22:39.751613 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:39.813159 [ 5803 ] {15ba29d6-fa7e-46c4-a397-679faeba218d} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 492.31 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36514) (comment: 01116_cross_count_asterisks.sql) (query 2, line 5) (in query: SELECT count(*) c FROM ( SELECT count(*), count(*) as c FROM numbers(2) AS n1, numbers(3) AS n2, numbers(4) AS n3 WHERE (n1.number = n2.number) AND (n2.number = n3.number) AND (SELECT count(*) FROM numbers(1)) = 1 ) WHERE (SELECT count(*) FROM numbers(2)) = 2 HAVING c IN(SELECT count(*) c FROM numbers(1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:22:39.849616 [ 5803 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 492.31 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:22:39.938949 [ 16233 ] {186ac4b1-06b9-49d1-8a56-a1c0adb98ce3} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 322, line 323) (in query: SELECT blockSize([NULL], [NULL], [NULL]);) 2025.11.13 09:22:39.952788 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:40.192722 [ 16233 ] {5033e67b-c7c1-42f2-8c57-009723e75283} executeQuery: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 323, line 324) (in query: SELECT boundingRatio([NULL], [NULL], [NULL]);) 2025.11.13 09:22:40.208431 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:40.213321 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 540.80 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:40.215220 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 540.80 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:40.266812 [ 16233 ] {bc209aae-73b5-4f19-8bec-c25a2c4417d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 324, line 325) (in query: SELECT buildId([NULL], [NULL], [NULL]);) 2025.11.13 09:22:40.278823 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:40.419917 [ 16233 ] {a6a7ed2a-0423-4bcc-8d03-e62b45f57329} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 325, line 326) (in query: SELECT byteHammingDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:40.433221 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:40.724143 [ 16233 ] {c2b014d0-2466-45b5-bb70-19020f40d243} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT byteSlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 327, line 328) (in query: SELECT byteSlice([NULL], [NULL], [NULL]);) 2025.11.13 09:22:40.737209 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT byteSlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:40.792568 [ 16233 ] {62471f9a-456e-418a-8e97-f7aed336eac8} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 328, line 329) (in query: SELECT byteSwap([NULL], [NULL], [NULL]);) 2025.11.13 09:22:40.803391 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:40.967982 [ 16233 ] {0209d7ac-573c-459f-8d07-36eb2b1b1ee9} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nullable(Nothing)) in function 'transform': In scope SELECT caseWithExpr([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 329, line 330) (in query: SELECT caseWithExpr([NULL], [NULL], [NULL]);) 2025.11.13 09:22:40.979127 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nullable(Nothing)) in function 'transform': In scope SELECT caseWithExpr([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.11.13 09:22:41.212760 [ 16233 ] {7e7e6c72-dabc-434d-9400-cbfeec47addd} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nullable(Nothing)) in function 'transform': In scope SELECT caseWithExpression([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 330, line 331) (in query: SELECT caseWithExpression([NULL], [NULL], [NULL]);) 2025.11.13 09:22:41.226039 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nullable(Nothing)) in function 'transform': In scope SELECT caseWithExpression([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.11.13 09:22:41.294726 [ 16233 ] {e781c99f-31be-4a90-a0f8-893fc86f4994} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 331, line 332) (in query: SELECT caseWithoutExpr([NULL], [NULL], [NULL]);) 2025.11.13 09:22:41.307918 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:41.364152 [ 16233 ] {2cf0e950-9ed8-4739-b952-f37c995372a5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpression([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 332, line 333) (in query: SELECT caseWithoutExpression([NULL], [NULL], [NULL]);) 2025.11.13 09:22:41.374990 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpression([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:41.442637 [ 16233 ] {d312cad3-4a30-41ff-a94a-3af4cdbefe0a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 333, line 334) (in query: SELECT catboostEvaluate([NULL], [NULL], [NULL]);) 2025.11.13 09:22:41.454021 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:41.567364 [ 16233 ] {d8376b89-97e4-43d4-824b-5dc6a62afb08} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 334, line 335) (in query: SELECT categoricalInformationValue([NULL], [NULL], [NULL]);) 2025.11.13 09:22:41.580675 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:41.636164 [ 16233 ] {ef4264a6-7ee9-413b-8e83-28da5b017764} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 335, line 336) (in query: SELECT cbrt([NULL], [NULL], [NULL]);) 2025.11.13 09:22:41.648515 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:41.803928 [ 16233 ] {0f06d26e-42b8-4170-8386-7911d331e5b6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceil([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 336, line 337) (in query: SELECT ceil([NULL], [NULL], [NULL]);) 2025.11.13 09:22:41.861821 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceil([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:41.874527 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 534.87 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:41.876339 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 534.87 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:41.934616 [ 16233 ] {2b2113da-4b63-4d78-8e5c-93673942b7b8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceiling([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 337, line 338) (in query: SELECT ceiling([NULL], [NULL], [NULL]);) 2025.11.13 09:22:41.946086 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceiling([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:42.007540 [ 16233 ] {65a862a7-9ea6-44f5-9eb6-627b66239d6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 338, line 339) (in query: SELECT changeDay([NULL], [NULL], [NULL]);) 2025.11.13 09:22:42.019517 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:42.056285 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:42.057384 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:42.119836 [ 16233 ] {ad664514-7a93-486d-b0b8-fdef59038bf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 339, line 340) (in query: SELECT changeHour([NULL], [NULL], [NULL]);) 2025.11.13 09:22:42.134835 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:42.193904 [ 16233 ] {af0cb0b3-bb8d-4e37-81d8-a3048312ced8} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 340, line 341) (in query: SELECT changeMinute([NULL], [NULL], [NULL]);) 2025.11.13 09:22:42.205204 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:42.274790 [ 16233 ] {049a5440-b1d5-4757-b94c-28bd819ffaa4} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 341, line 342) (in query: SELECT changeMonth([NULL], [NULL], [NULL]);) 2025.11.13 09:22:42.285888 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:42.288637 [ 18391 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:22:42.289570 [ 18391 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:42.504665 [ 16233 ] {e928e29b-928c-4bcd-afee-e2a56d738d74} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 342, line 343) (in query: SELECT changeSecond([NULL], [NULL], [NULL]);) 2025.11.13 09:22:42.518300 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:42.657843 [ 16233 ] {10bbd968-0ca7-41cc-9f3a-a8dfd413fc3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 343, line 344) (in query: SELECT changeYear([NULL], [NULL], [NULL]);) 2025.11.13 09:22:42.671188 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:42.799721 [ 16233 ] {a910f6ad-7d73-4b5f-bb51-ad15ae8afeeb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function char, must be Int, UInt or Float number: In scope SELECT char([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 344, line 345) (in query: SELECT char([NULL], [NULL], [NULL]);) 2025.11.13 09:22:42.813865 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function char, must be Int, UInt or Float number: In scope SELECT char([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:42.976791 [ 18391 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:22:42.977800 [ 18391 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:43.003054 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 512.19 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:43.005095 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 512.19 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:43.438097 [ 16233 ] {c6407c02-1dc1-48b4-aa14-7eba33840b29} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 3 arguments: In scope SELECT compareSubstrings([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 348, line 349) (in query: SELECT compareSubstrings([NULL], [NULL], [NULL]);) 2025.11.13 09:22:43.452885 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'compareSubstrings'. Expected 5 arguments, got 3 arguments: In scope SELECT compareSubstrings([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:43.769545 [ 16233 ] {d775caac-e1a1-4d98-bb4b-9f14984fea0f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 351, line 352) (in query: SELECT concatWithSeparator([NULL], [NULL], [NULL]);) 2025.11.13 09:22:43.783140 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:43.829908 [ 19606 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 501.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:43.830799 [ 19606 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 501.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:43.843166 [ 16233 ] {cd6deb4e-254b-4480-84bf-3020beb96389} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 352, line 353) (in query: SELECT concatWithSeparatorAssumeInjective([NULL], [NULL], [NULL]);) 2025.11.13 09:22:43.854523 [ 5639 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:22:43.855650 [ 5639 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:43.855671 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:43.969897 [ 16233 ] {4dc684f1-63b0-408b-aa7c-36f104fa588e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparator: In scope SELECT concat_ws([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 353, line 354) (in query: SELECT concat_ws([NULL], [NULL], [NULL]);) 2025.11.13 09:22:43.981836 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparator: In scope SELECT concat_ws([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:44.033390 [ 16354 ] {601b1474-61d5-4f0e-82bc-0fe593f5bb61} executeQuery: Code: 57. DB::Exception: Table test_clcj9b31.`table` already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36556) (comment: 00838_system_tables_drop_table_race.sh) (query 37, line 19) (in query: CREATE TABLE `table` (`x` UInt8) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 55451, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.8493990302085876, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 288851162, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 4224596, merge_max_block_size = 9869, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10716060919, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 6444629636, index_granularity_bytes = 5958895, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 20, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 53442, primary_key_compress_block_size = 27442, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:22:44.041724 [ 16233 ] {a505cc9d-53eb-4514-9c81-7899092d1b1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 354, line 355) (in query: SELECT connectionId([NULL], [NULL], [NULL]);) 2025.11.13 09:22:44.051829 [ 16354 ] {} TCPHandler: Code: 57. DB::Exception: Table test_clcj9b31.`table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:22:44.052523 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:44.098313 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 506.98 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:44.100207 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 506.98 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:44.109358 [ 16233 ] {e5a99c95-f83b-4280-b4a4-350ed6a7edf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 355, line 356) (in query: SELECT connection_id([NULL], [NULL], [NULL]);) 2025.11.13 09:22:44.123153 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:44.188913 [ 16233 ] {cdc99767-3b66-4f62-b3b5-871c88217b97} executeQuery: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 356, line 357) (in query: SELECT contingency([NULL], [NULL], [NULL]);) 2025.11.13 09:22:44.200878 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:44.294668 [ 3725 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_82_14} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 500.98 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column ProfileEvent_DictCacheKeysExpired): (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_1_77_13/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 1 with max_rows_to_read = 1531): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7ac08c 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:44.296397 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_82_14}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 500.98 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column ProfileEvent_DictCacheKeysExpired): (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_1_77_13/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 1 with max_rows_to_read = 1531): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7ac08c 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 18. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 19. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:44.340889 [ 5803 ] {8b3a58a2-40f6-4134-9839-a53e4d253206} executeQuery: Code: 400. DB::ErrnoException: Cannot stat file /var/lib/clickhouse/user_files/reading/03262_test_parquet_native_reader_int_logical_type_test_11/multi_column_bf.gz.parquet: , errno: 2, strerror: No such file or directory: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/reading/03262_test_parquet_native_reader_int_logical_type_test_11/multi_column_bf.gz.parquet). (CANNOT_STAT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34480) (comment: 03262_test_parquet_native_reader_int_logical_type.sh) (query 1, line 1) (in query: select int8_logical, uint16_logical, uint64_logical from file('reading/03262_test_parquet_native_reader_int_logical_type_test_11/multi_column_bf.gz.parquet', Parquet) order by uint64_logical limit 20 SETTINGS input_format_parquet_use_native_reader=false;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000003854b3af 4. ./build_docker/./src/Storages/StorageFile.cpp:352: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x000000003853f251 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0e238a 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 14. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:22:44.353856 [ 5803 ] {} TCPHandler: Code: 400. DB::ErrnoException: Cannot stat file /var/lib/clickhouse/user_files/reading/03262_test_parquet_native_reader_int_logical_type_test_11/multi_column_bf.gz.parquet: , errno: 2, strerror: No such file or directory: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/reading/03262_test_parquet_native_reader_int_logical_type_test_11/multi_column_bf.gz.parquet). (CANNOT_STAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000003854b3af 4. ./build_docker/./src/Storages/StorageFile.cpp:352: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x000000003853f251 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0e238a 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 14. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:22:44.429748 [ 16233 ] {f3c26fce-4284-46dd-aadd-ea5f3ef7881a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function convertCharset, must be String: In scope SELECT convertCharset([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 357, line 358) (in query: SELECT convertCharset([NULL], [NULL], [NULL]);) 2025.11.13 09:22:44.508031 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function convertCharset, must be String: In scope SELECT convertCharset([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:44.558709 [ 16233 ] {1fbb93c2-6065-43a0-bd77-7dd033e04bcc} executeQuery: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 358, line 359) (in query: SELECT corr([NULL], [NULL], [NULL]);) 2025.11.13 09:22:44.571231 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:44.633195 [ 16233 ] {bbe10c15-a72f-4e32-b19b-97dbbfb8222d} executeQuery: Code: 43. DB::Exception: Aggregate function corrMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 359, line 360) (in query: SELECT corrMatrix([NULL], [NULL], [NULL]);) 2025.11.13 09:22:44.645513 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function corrMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:44.760881 [ 16233 ] {276f72bc-78ad-4bec-9ce3-8b8c6deb4f7a} executeQuery: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 360, line 361) (in query: SELECT corrStable([NULL], [NULL], [NULL]);) 2025.11.13 09:22:44.771625 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:44.836843 [ 16233 ] {ec85aa94-8309-4f9d-8d61-88f0e70a654b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 361, line 362) (in query: SELECT cos([NULL], [NULL], [NULL]);) 2025.11.13 09:22:44.847877 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:44.907945 [ 16233 ] {b1aba3f4-a691-4ed4-bc86-5cc2c9951cb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 362, line 363) (in query: SELECT cosh([NULL], [NULL], [NULL]);) 2025.11.13 09:22:44.919186 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:44.981086 [ 16233 ] {1441e23f-c858-4765-b6da-5e89ee0c2755} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 363, line 364) (in query: SELECT cosineDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:44.993045 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:45.051212 [ 16233 ] {01e9214c-962a-4fcc-bb6c-c43a7395befe} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 364, line 365) (in query: SELECT count([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.061936 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:45.122058 [ 16233 ] {13a6627b-767c-4164-a328-8cc168cccd47} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 365, line 366) (in query: SELECT countDigits([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.133029 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:45.192399 [ 16233 ] {a4e55fce-c556-4847-99d7-663a0298b26e} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 366, line 367) (in query: SELECT countEqual([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.203804 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:45.262689 [ 16233 ] {d6b7b439-62c5-4a7f-8399-f5cd0b40b0c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 367, line 368) (in query: SELECT countMatches([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.274134 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:45.301875 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.00 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:45.303814 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.00 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:45.337064 [ 16233 ] {a4b82383-229b-407e-bba2-5f0dbdb9c690} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 368, line 369) (in query: SELECT countMatchesCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.341463 [ 5803 ] {c8e18582-821f-4659-9228-e04459326f12} executeQuery: Code: 400. DB::ErrnoException: Cannot stat file /var/lib/clickhouse/user_files/reading/03262_test_parquet_native_reader_int_logical_type_test_11/multi_column_bf.gz.parquet: , errno: 2, strerror: No such file or directory: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/reading/03262_test_parquet_native_reader_int_logical_type_test_11/multi_column_bf.gz.parquet). (CANNOT_STAT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34562) (comment: 03262_test_parquet_native_reader_int_logical_type.sh) (query 1, line 1) (in query: select int8_logical, uint16_logical, uint64_logical from file('reading/03262_test_parquet_native_reader_int_logical_type_test_11/multi_column_bf.gz.parquet', Parquet) order by uint64_logical limit 20 SETTINGS input_format_parquet_use_native_reader=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000003854b3af 4. ./build_docker/./src/Storages/StorageFile.cpp:352: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x000000003853f251 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0e238a 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 14. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:22:45.349154 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:45.360256 [ 5803 ] {} TCPHandler: Code: 400. DB::ErrnoException: Cannot stat file /var/lib/clickhouse/user_files/reading/03262_test_parquet_native_reader_int_logical_type_test_11/multi_column_bf.gz.parquet: , errno: 2, strerror: No such file or directory: The table structure cannot be extracted from a Parquet format file. You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/reading/03262_test_parquet_native_reader_int_logical_type_test_11/multi_column_bf.gz.parquet). (CANNOT_STAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type>, String const&) @ 0x000000003854b3af 4. ./build_docker/./src/Storages/StorageFile.cpp:352: DB::(anonymous namespace)::ReadBufferFromFileIterator::next() @ 0x000000003853f251 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0e238a 6. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 7. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 8. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 9. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 10. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 11. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 12. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 14. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 15. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 16. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:22:45.408398 [ 16233 ] {30eb1e02-bd6b-4386-a437-5c302785b40c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstrings: In scope SELECT countSubstrings([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 369, line 370) (in query: SELECT countSubstrings([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.419239 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstrings: In scope SELECT countSubstrings([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:45.543287 [ 16233 ] {940b6e1b-9cc9-4b77-9fa8-ae8ececfcaa4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstringsCaseInsensitive: In scope SELECT countSubstringsCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 370, line 371) (in query: SELECT countSubstringsCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.554486 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstringsCaseInsensitive: In scope SELECT countSubstringsCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:45.582436 [ 19606 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:22:45.583416 [ 19606 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:45.618535 [ 16233 ] {65ddf1ce-eb19-4044-9207-f48d7b7857fd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstringsCaseInsensitiveUTF8: In scope SELECT countSubstringsCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 371, line 372) (in query: SELECT countSubstringsCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.685183 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstringsCaseInsensitiveUTF8: In scope SELECT countSubstringsCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:45.730111 [ 16233 ] {a927356e-e31b-4502-b0c3-21ce7398ad77} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 372, line 373) (in query: SELECT covarPop([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.741366 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:45.807778 [ 16233 ] {7f57ba42-79bb-4de6-8f6e-8532ec5f1e50} executeQuery: Code: 43. DB::Exception: Aggregate function covarPopMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 373, line 374) (in query: SELECT covarPopMatrix([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.820658 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function covarPopMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:45.878961 [ 16233 ] {025936ca-c84a-4b04-a87a-58b13ef21a68} executeQuery: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 374, line 375) (in query: SELECT covarPopStable([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.890455 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:45.944000 [ 16233 ] {8cde3918-acfc-4451-9f08-f389fe165820} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 375, line 376) (in query: SELECT covarSamp([NULL], [NULL], [NULL]);) 2025.11.13 09:22:45.955481 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:46.016764 [ 16233 ] {0950d736-e79b-4984-a0f1-6174ac5b7fe4} executeQuery: Code: 43. DB::Exception: Aggregate function covarSampMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 376, line 377) (in query: SELECT covarSampMatrix([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.029119 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function covarSampMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:46.084800 [ 16233 ] {cdf8fa55-0bc2-4336-8882-39060e7a7316} executeQuery: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 377, line 378) (in query: SELECT covarSampStable([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.097026 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:46.242691 [ 16233 ] {3452dc91-b6e3-48f5-a3b9-b204302b6cd5} executeQuery: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 378, line 379) (in query: SELECT cramersV([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.261441 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:46.320562 [ 16233 ] {efb278b6-17c1-4416-8ecf-4ac8e6088343} executeQuery: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 379, line 380) (in query: SELECT cramersVBiasCorrected([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.343527 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:46.401645 [ 16233 ] {7c010392-61d9-4019-8fd1-3c08d4366717} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 380, line 381) (in query: SELECT curdate([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.414229 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:46.470958 [ 16233 ] {447ad821-85b4-4ad2-8362-789d3480d4f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 381, line 382) (in query: SELECT currentDatabase([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.484889 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:46.518520 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 506.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:46.520799 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 506.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:46.638463 [ 16233 ] {2df2343d-e6fc-4a6b-b7cf-7f65c5b85514} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 382, line 383) (in query: SELECT currentProfiles([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.651050 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:46.710894 [ 16233 ] {c42b4f64-9281-49dc-a17a-460eb71842c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT currentQueryID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 383, line 384) (in query: SELECT currentQueryID([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.722996 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT currentQueryID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:46.766949 [ 16132 ] {0a273b17-38b0-43f9-b0e4-0820824fe7b7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34506) (comment: 01285_date_datetime_key_condition.sql) (query 7, line 11) (in query: -- inside SELECT groupArray(dt) from date_datetime_key_condition WHERE dt > toDate('2019-01-02');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:46.787102 [ 16233 ] {6381fdbd-9cf6-4b27-8973-50fcdf4c25d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 384, line 385) (in query: SELECT currentRoles([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.800018 [ 16132 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:22:46.806296 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:46.918481 [ 16233 ] {adbf0cc7-4fb4-423c-9ced-80533dd41cb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 385, line 386) (in query: SELECT currentSchemas([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.929532 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:46.985196 [ 16233 ] {eb378278-6d63-46f3-88a7-7a11850af8bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 386, line 387) (in query: SELECT currentUser([NULL], [NULL], [NULL]);) 2025.11.13 09:22:46.996038 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:47.139522 [ 16233 ] {0a7214f2-fabc-443c-9edd-40517161ec79} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 387, line 388) (in query: SELECT current_database([NULL], [NULL], [NULL]);) 2025.11.13 09:22:47.151682 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:47.228192 [ 16233 ] {2209741d-9c39-40a3-9e54-1ebc9862cd52} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 388, line 389) (in query: SELECT current_date([NULL], [NULL], [NULL]);) 2025.11.13 09:22:47.241709 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:47.323831 [ 16233 ] {556a64b4-b08b-4356-b625-1a08637e7992} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT current_query_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 389, line 390) (in query: SELECT current_query_id([NULL], [NULL], [NULL]);) 2025.11.13 09:22:47.336704 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentQueryID doesn't match: passed 3, should be 0: In scope SELECT current_query_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:47.403605 [ 5803 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:22:47.404863 [ 5803 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:47.434210 [ 16233 ] {fa992cbe-42cb-4b81-9e5e-b8fa47ff2389} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 390, line 391) (in query: SELECT current_schemas([NULL], [NULL], [NULL]);) 2025.11.13 09:22:47.446411 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:47.510217 [ 16233 ] {faaec48a-e9da-4d20-999f-156d9c8add4d} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 391, line 392) (in query: SELECT current_timestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:22:47.524628 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:47.587991 [ 16233 ] {2a7c2610-04b6-4ca0-9277-b12a6fb9d262} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 392, line 393) (in query: SELECT current_user([NULL], [NULL], [NULL]);) 2025.11.13 09:22:47.599262 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:47.664683 [ 16233 ] {17dc942a-5648-4027-ac1b-37a3f6d23ca7} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 393, line 394) (in query: SELECT cutFragment([NULL], [NULL], [NULL]);) 2025.11.13 09:22:47.676289 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:47.739941 [ 16233 ] {b468edc3-667a-41fd-8dc1-dc7d9b1960b0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function cutIPv6, expected FixedString(16): In scope SELECT cutIPv6([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 394, line 395) (in query: SELECT cutIPv6([NULL], [NULL], [NULL]);) 2025.11.13 09:22:47.863345 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function cutIPv6, expected FixedString(16): In scope SELECT cutIPv6([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:47.929395 [ 16233 ] {b97ebe90-5722-43d6-b2f7-429c07d32792} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 395, line 396) (in query: SELECT cutQueryString([NULL], [NULL], [NULL]);) 2025.11.13 09:22:47.955082 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.007871 [ 16233 ] {f9d45b79-3e53-4b9a-86e0-d1c939daccea} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 396, line 397) (in query: SELECT cutQueryStringAndFragment([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.009866 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 548.85 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:48.011958 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 548.85 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:48.020408 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.188649 [ 5803 ] {fdea8136-f883-48f1-b986-777e3e7210cc} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34640) (comment: 02943_order_by_all.sql) (query 5, line 16) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:22:48.195754 [ 5803 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:22:48.198167 [ 16233 ] {79374145-63b2-44f3-8d70-6f4e9de6746b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 397, line 398) (in query: SELECT cutToFirstSignificantSubdomain([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.211108 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.278636 [ 16233 ] {61ffab6b-1dab-45f1-adf1-e815a4ad8812} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 398, line 399) (in query: SELECT cutToFirstSignificantSubdomainCustom([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.293605 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.358434 [ 16233 ] {77600ff0-686a-4f26-984c-ed0f0d84e8e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 399, line 400) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.405452 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.452027 [ 16233 ] {ed5e6c25-6f46-4db3-9ad2-28618a841166} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 400, line 401) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.464058 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.520464 [ 16233 ] {3804d3d3-80fb-4546-bc86-1a8a9d1a36b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 401, line 402) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.532095 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.613118 [ 16233 ] {a8119662-e1ef-430d-b9bf-6eaf9b11e5a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 402, line 403) (in query: SELECT cutToFirstSignificantSubdomainRFC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.627315 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.690668 [ 16233 ] {cc754598-e5cd-47af-9b0b-f75bdd8b1f1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 403, line 404) (in query: SELECT cutToFirstSignificantSubdomainWithWWW([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.702818 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.802903 [ 16233 ] {6eb09ab4-4762-4b20-b363-00563ebc33be} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 404, line 405) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.814475 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.876182 [ 16233 ] {40f97422-0daf-4b3e-9dd4-6fbdcf90a22c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 405, line 406) (in query: SELECT cutURLParameter([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.887099 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:48.950811 [ 16233 ] {3ff4bb6b-814c-4afa-b301-44617b58254b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 406, line 407) (in query: SELECT cutWWW([NULL], [NULL], [NULL]);) 2025.11.13 09:22:48.961697 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:49.019008 [ 16233 ] {384e1be4-9347-47ec-8e68-e2eed8077684} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 407, line 408) (in query: SELECT damerauLevenshteinDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:49.030962 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:49.092546 [ 16233 ] {2a3fe31d-a793-416e-a77c-f233bf42bd95} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 408, line 409) (in query: SELECT dateDiff([NULL], [NULL], [NULL]);) 2025.11.13 09:22:49.103612 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:49.161972 [ 16233 ] {db6b569e-693b-41ce-93c5-36e0688d50d8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1 argument of function dateName. Must be string: In scope SELECT dateName([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 409, line 410) (in query: SELECT dateName([NULL], [NULL], [NULL]);) 2025.11.13 09:22:49.174851 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1 argument of function dateName. Must be string: In scope SELECT dateName([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:49.237367 [ 16233 ] {ae1b20ba-60d6-4427-bea2-2863d3cb072c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 410, line 411) (in query: SELECT dateTime64ToSnowflake([NULL], [NULL], [NULL]);) 2025.11.13 09:22:49.251381 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:49.304502 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 516.58 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:49.306512 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 516.58 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:49.320592 [ 16233 ] {43ee211d-ff61-4738-91c8-55fc07c148b1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTime64ToSnowflakeID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 411, line 412) (in query: SELECT dateTime64ToSnowflakeID([NULL], [NULL], [NULL]);) 2025.11.13 09:22:49.379171 [ 3734 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_78_83_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 486.73 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:49.381110 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_78_83_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 486.73 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:49.385837 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTime64ToSnowflakeID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:49.439459 [ 16233 ] {6bb9a394-84c5-48bb-9aed-40f371389ea4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 412, line 413) (in query: SELECT dateTimeToSnowflake([NULL], [NULL], [NULL]);) 2025.11.13 09:22:49.449958 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:49.513205 [ 16233 ] {ed77d81f-71bb-48a6-b209-3eefbeebb67e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTimeToSnowflakeID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 413, line 414) (in query: SELECT dateTimeToSnowflakeID([NULL], [NULL], [NULL]);) 2025.11.13 09:22:49.525033 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTimeToSnowflakeID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:49.583552 [ 18391 ] {c20468a4-818e-40aa-baf8-1a62d89d0168} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 483.49 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34516) (query 24, line 24) (in query: SELECT avgWeighted(x, w) FROM values('x Int16, w Int16', (0, 0), (1, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:22:49.586364 [ 16233 ] {5fe2be62-eca6-41c9-ad8a-c79d98a52179} executeQuery: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT dateTrunc([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 414, line 415) (in query: SELECT dateTrunc([NULL], [NULL], [NULL]);) 2025.11.13 09:22:49.598314 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT dateTrunc([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:49.599795 [ 18391 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 483.49 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:22:49.722115 [ 16233 ] {999f496f-1583-4d28-8470-371349fb1e58} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT date_bin([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 415, line 416) (in query: SELECT date_bin([NULL], [NULL], [NULL]);) 2025.11.13 09:22:49.735065 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT date_bin([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:49.744407 [ 5803 ] {5733ec46-3e44-4c56-9d48-c1ac0fa7cbb1} executeQuery: Code: 80. DB::Exception: Query from view test_13.v returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34656) (comment: 03010_view_prewhere_in.sql) (query 4, line 13) (in query: SELECT date, value FROM v;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageView.cpp:203: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038eabc25 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:22:49.747905 [ 3912 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryMetricLogElement]: Failed to flush system log system.query_metric_log with 4 entries up to offset 4922: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.49 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037b1704e 10. ./src/Common/COW.h:293: DB::ColumnVector::cloneResized(unsigned long) const @ 0x0000000037b28bc1 11. DB::IColumn::cloneEmpty() const @ 0x000000002c156c44 12. ./build_docker/./src/Core/ColumnWithTypeAndName.cpp:21: DB::ColumnWithTypeAndName::cloneEmpty() const @ 0x000000002eb2689a 13. ./build_docker/./src/Core/Block.cpp:502: DB::Block::cloneEmpty() const @ 0x000000002eaff97e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:579: DB::MergeTreeDataPartWriterOnDisk::initOrAdjustDynamicStructureIfNeeded(DB::Block&) @ 0x0000000039bd16ae 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:177: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba565f 16. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 20. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 28. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000333e0dcc 29. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x00000000333de236 30. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba9d61 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba9b9f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:49.766379 [ 5803 ] {} TCPHandler: Code: 80. DB::Exception: Query from view test_13.v returned Nullable column having not Nullable type in structure. If query from view has JOIN, it may be cause by different values of 'join_use_nulls' setting. You may explicitly specify 'join_use_nulls' in 'CREATE VIEW' query to avoid this error. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageView.cpp:203: DB::StorageView::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038eabc25 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:22:49.832007 [ 16233 ] {b1f07500-1a7a-4af3-bb51-1fbbe165c6ed} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 416, line 417) (in query: SELECT date_diff([NULL], [NULL], [NULL]);) 2025.11.13 09:22:49.842721 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:50.074777 [ 16233 ] {07d8e92a-a40b-4578-8162-56871f7515f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 417, line 418) (in query: SELECT decodeHTMLComponent([NULL], [NULL], [NULL]);) 2025.11.13 09:22:50.086165 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:50.150569 [ 16233 ] {5a8dd647-485f-44aa-bd6d-2d43e42ab9c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 418, line 419) (in query: SELECT decodeURLComponent([NULL], [NULL], [NULL]);) 2025.11.13 09:22:50.197584 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:50.243661 [ 16233 ] {115f8fe6-1a24-444f-b908-e64052dde163} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 419, line 420) (in query: SELECT decodeURLFormComponent([NULL], [NULL], [NULL]);) 2025.11.13 09:22:50.254288 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:50.317668 [ 16233 ] {ae2fe7ab-033b-43ee-83a4-84fde0e06296} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 420, line 421) (in query: SELECT decodeXMLComponent([NULL], [NULL], [NULL]);) 2025.11.13 09:22:50.383693 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:50.435675 [ 16233 ] {66c7b1c6-4e36-436b-a97a-9dd35ee3a9cb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'decrypt'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT decrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 421, line 422) (in query: SELECT decrypt([NULL], '[HIDDEN]')) 2025.11.13 09:22:50.447355 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'decrypt'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT decrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:50.512197 [ 16233 ] {523b1ca0-f08d-4707-8ce4-08ae332fe594} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 422, line 423) (in query: SELECT defaultProfiles([NULL], [NULL], [NULL]);) 2025.11.13 09:22:50.525822 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:50.583874 [ 16233 ] {08efdfa1-9729-4eea-b5c1-166e4b0b94fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 423, line 424) (in query: SELECT defaultRoles([NULL], [NULL], [NULL]);) 2025.11.13 09:22:50.595157 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:50.666386 [ 16233 ] {63bfec77-0688-49a0-9214-22029c12bc1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 424, line 425) (in query: SELECT defaultValueOfArgumentType([NULL], [NULL], [NULL]);) 2025.11.13 09:22:50.677483 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:50.732815 [ 16233 ] {17cd715c-13dd-4c29-8536-64a0bcbeec7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 425, line 426) (in query: SELECT defaultValueOfTypeName([NULL], [NULL], [NULL]);) 2025.11.13 09:22:50.746379 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:50.879807 [ 16233 ] {be5dbddc-a493-4822-8fd2-649133c51d40} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 426, line 427) (in query: SELECT degrees([NULL], [NULL], [NULL]);) 2025.11.13 09:22:50.892308 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:50.932576 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 575.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:50.933656 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 575.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:50.973226 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 577.27 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:50.975032 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 577.27 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:51.045142 [ 16233 ] {f39cfec5-3e76-4bff-bc1f-29667fdb8e46} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 427, line 428) (in query: SELECT deltaSum([NULL], [NULL], [NULL]);) 2025.11.13 09:22:51.056226 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:51.116033 [ 16233 ] {7f7bee85-a5e8-44e6-bc35-78f584e3ed5a} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 428, line 429) (in query: SELECT deltaSumTimestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:22:51.129137 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:51.192315 [ 16233 ] {565c2de0-88b4-4564-8b4a-802c1fca13bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 429, line 430) (in query: SELECT demangle([NULL], [NULL], [NULL]);) 2025.11.13 09:22:51.206023 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:51.414941 [ 16233 ] {d940193c-b9c7-4505-aec5-58a2d6d3c598} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 430, line 431) (in query: SELECT denseRank([NULL], [NULL], [NULL]);) 2025.11.13 09:22:51.450398 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:22:51.578159 [ 16233 ] {66aaaebf-0f7c-4cf8-bc16-a6307510ffd2} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 431, line 432) (in query: SELECT dense_rank([NULL], [NULL], [NULL]);) 2025.11.13 09:22:51.613379 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:22:51.667785 [ 16233 ] {c488c649-3689-42fe-bede-b1abcb8ff69a} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 432, line 433) (in query: SELECT detectCharset([NULL], [NULL], [NULL]);) 2025.11.13 09:22:51.679906 [ 16233 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:22:51.776856 [ 16233 ] {af0c8d4a-83f6-480f-ab91-b57691354cbd} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 433, line 434) (in query: SELECT detectLanguage([NULL], [NULL], [NULL]);) 2025.11.13 09:22:51.788249 [ 16233 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:22:51.921238 [ 16233 ] {381bd95f-e92d-44a7-89bb-e831df06d045} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 434, line 435) (in query: SELECT detectLanguageMixed([NULL], [NULL], [NULL]);) 2025.11.13 09:22:51.933813 [ 16233 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:22:52.099277 [ 16233 ] {b4800d52-b4da-4c28-9703-09d20d7e94fb} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 435, line 436) (in query: SELECT detectLanguageUnknown([NULL], [NULL], [NULL]);) 2025.11.13 09:22:52.111581 [ 16233 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:22:52.172725 [ 16233 ] {8f0da7d4-cfb1-4509-a883-c63cbacb7c00} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 436, line 437) (in query: SELECT detectProgrammingLanguage([NULL], [NULL], [NULL]);) 2025.11.13 09:22:52.184057 [ 16233 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:22:52.239367 [ 16233 ] {57371548-7850-48f8-af4e-8d532ea8a4bc} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 437, line 438) (in query: SELECT detectTonality([NULL], [NULL], [NULL]);) 2025.11.13 09:22:52.250826 [ 16233 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:22:52.283122 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 541.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:52.285252 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 541.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:52.311292 [ 16233 ] {555b4a1f-2e53-4afb-8791-76097fec4cf0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 438, line 439) (in query: SELECT dictGet([NULL], [NULL], [NULL]);) 2025.11.13 09:22:52.322120 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:52.353342 [ 18391 ] {fc93908e-fc25-4500-b6aa-6c9ce5f6dbab} executeQuery: Code: 43. DB::Exception: Types Array(String) and Float64 are non-conforming as arguments for aggregate function avgWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34702) (comment: 01035_avg_weighted_long.sh) (query 1, line 1) (in query: SELECT avgWeighted(['string'], toFloat64(0))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000209d1057 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAvgWeighted.cpp:176: DB::(anonymous namespace)::createAggregateFunctionAvgWeighted(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204bf12f 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:52.365931 [ 18391 ] {} TCPHandler: Code: 43. DB::Exception: Types Array(String) and Float64 are non-conforming as arguments for aggregate function avgWeighted. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000209d1057 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAvgWeighted.cpp:176: DB::(anonymous namespace)::createAggregateFunctionAvgWeighted(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204bf12f 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl[abi:ne190107] (*)(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*), std::shared_ptr (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000204be383 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d163b3b 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000002d15ee9e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3369: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030473b59 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 23. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 24. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 26. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 29. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 2025.11.13 09:22:52.500925 [ 16233 ] {9947e455-24a4-49d9-923d-c5e1389e99a3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 439, line 440) (in query: SELECT dictGetAll([NULL], [NULL], [NULL]);) 2025.11.13 09:22:52.512722 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:52.606620 [ 16233 ] {17f275b9-84fe-4e52-9597-f5bffe87f03d} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 440, line 441) (in query: SELECT dictGetChildren([NULL], [NULL], [NULL]);) 2025.11.13 09:22:52.618947 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:52.689569 [ 16233 ] {3bbd8109-db88-42f4-aded-c59931ffcaf5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 441, line 442) (in query: SELECT dictGetDate([NULL], [NULL], [NULL]);) 2025.11.13 09:22:52.701744 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:52.768924 [ 16233 ] {d84dd2c0-afbf-41ed-be67-b7a5d4d87936} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 442, line 443) (in query: SELECT dictGetDateOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:52.810849 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:52.872562 [ 16233 ] {725bc2a9-0831-44a8-896f-9cee6a2bc8e5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 443, line 444) (in query: SELECT dictGetDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:22:52.884034 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:53.027372 [ 16233 ] {a9897c6c-7c9a-4ca0-a372-bd3c5114e12b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateTimeOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 444, line 445) (in query: SELECT dictGetDateTimeOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:53.042852 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateTimeOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:53.104772 [ 16233 ] {687130ef-f75c-40cc-a1c1-f7fc810623ee} executeQuery: Code: 43. DB::Exception: Illegal type of first argument of function dictGetDescendants. Expected const String. Actual type Array(Nullable(Nothing)): In scope SELECT dictGetDescendants([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 445, line 446) (in query: SELECT dictGetDescendants([NULL], [NULL], [NULL]);) 2025.11.13 09:22:53.117913 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type of first argument of function dictGetDescendants. Expected const String. Actual type Array(Nullable(Nothing)): In scope SELECT dictGetDescendants([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:53.259205 [ 16233 ] {3ea46102-18b8-4ebf-89d2-335d2754284b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 446, line 447) (in query: SELECT dictGetFloat32([NULL], [NULL], [NULL]);) 2025.11.13 09:22:53.276509 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:53.393357 [ 16233 ] {89f66263-50d0-4983-8f21-18f3ca6939a1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 447, line 448) (in query: SELECT dictGetFloat32OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:53.408756 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:53.415332 [ 17388 ] {045373ae-b473-4f6a-81b7-911643399166} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56436) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_01516_test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:22:53.442698 [ 17388 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:22:53.473486 [ 16233 ] {8266c4bf-9057-4706-869e-0e1c9fe46fa8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 448, line 449) (in query: SELECT dictGetFloat64([NULL], [NULL], [NULL]);) 2025.11.13 09:22:53.474793 [ 3739 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 533.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:53.477055 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 533.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:53.488022 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:53.568765 [ 2997 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 499.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:53.605069 [ 2997 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 499.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:53.642487 [ 16233 ] {b338e91f-a2bf-464a-a7c3-ff58b0ed86f9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 449, line 450) (in query: SELECT dictGetFloat64OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:53.664248 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:53.716532 [ 16233 ] {2357ef0f-9ed0-43db-9bb4-28e1365d54ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 450, line 451) (in query: SELECT dictGetHierarchy([NULL], [NULL], [NULL]);) 2025.11.13 09:22:53.729474 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:53.789217 [ 16233 ] {d5445452-b4de-48a8-a843-98f41388eb30} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv4([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 451, line 452) (in query: SELECT dictGetIPv4([NULL], [NULL], [NULL]);) 2025.11.13 09:22:53.885558 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 527.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:53.887892 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv4([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:53.888026 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 527.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:53.980483 [ 16233 ] {22f07946-eba3-4352-9857-19f215acf175} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv4OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 452, line 453) (in query: SELECT dictGetIPv4OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:53.999727 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv4OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:54.063892 [ 16233 ] {414340b6-6c11-4744-866b-26524e72ab44} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv6([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 453, line 454) (in query: SELECT dictGetIPv6([NULL], [NULL], [NULL]);) 2025.11.13 09:22:54.080225 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv6([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:54.240975 [ 16233 ] {0a16074b-205b-45a1-a89d-597d9871d9ba} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv6OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 454, line 455) (in query: SELECT dictGetIPv6OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:54.257545 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv6OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:54.334004 [ 16233 ] {c32a0191-495a-4669-9fd2-b9ccd88aeed3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt16([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 455, line 456) (in query: SELECT dictGetInt16([NULL], [NULL], [NULL]);) 2025.11.13 09:22:54.349430 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt16([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:54.413801 [ 16233 ] {50815335-fe94-44e1-ab69-1616a8eabc9c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt16OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 456, line 457) (in query: SELECT dictGetInt16OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:54.447391 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt16OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:54.512598 [ 16233 ] {f82f22ea-3d18-4447-b625-da694fc2e0b1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 457, line 458) (in query: SELECT dictGetInt32([NULL], [NULL], [NULL]);) 2025.11.13 09:22:54.540989 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:54.597609 [ 16233 ] {8dfc06ce-0c41-4b83-a504-1cb896eeb214} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 458, line 459) (in query: SELECT dictGetInt32OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:54.609364 [ 3725 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_78_83_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 524.51 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:54.609642 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 546.25 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:54.611177 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_78_83_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 524.51 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:54.611768 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 546.25 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:54.616386 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:54.673521 [ 16233 ] {9d2b4304-e205-49df-a804-9f0151374c95} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 459, line 460) (in query: SELECT dictGetInt64([NULL], [NULL], [NULL]);) 2025.11.13 09:22:54.699970 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:54.788304 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 517.42 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:54.790400 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_104_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 517.42 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:54.848904 [ 16233 ] {34f6644c-aae4-47ea-bf64-05741419ed69} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 460, line 461) (in query: SELECT dictGetInt64OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:54.864335 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:54.868222 [ 19606 ] {be1d997f-738f-4386-8042-06e403221e4b} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 506.64 MiB (attempt to allocate chunk of 8.49 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52914) (comment: 00710_array_enumerate_dense.sql) (query 1, line 1) (in query: -- empty result set SELECT a FROM (SELECT groupArray(intDiv(number, 54321)) AS a, arrayUniq(a) AS u, arrayEnumerateDense(a) AS arr FROM (SELECT number FROM system.numbers LIMIT 1000000) GROUP BY intHash32(number) % 100000) where u <> arrayReverseSort(arr)[1];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b1f4f78 12. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b1f49e5 13. ./src/Common/Arena.h:321: DB::MixedArenaAllocator<4096ul, Allocator, DB::AlignedArenaAllocator<8ul>, 8ul>::realloc(void*, unsigned long, unsigned long, DB::Arena*) @ 0x0000000020e708c2 14. ./src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 32ul, DB::MixedArenaAllocator<4096ul, Allocator, DB::AlignedArenaAllocator<8ul>, 8ul>, 0ul, 0ul>::reserveForNextSize(DB::Arena*&) @ 0x0000000020e70454 15. ./src/Common/PODArray.h:428: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000020c8e3b8 16. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000031cad8c3 17. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003213c5c3 18. ./build_docker/./src/Interpreters/Aggregator.cpp:992: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000032135c95 19. ./build_docker/./src/Interpreters/Aggregator.cpp:952: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031e92104 20. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031ca8d5b 21. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb4455 22. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 23. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:22:54.925544 [ 16233 ] {6c80de22-b6cc-499c-8dca-62fbc087b506} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 461, line 462) (in query: SELECT dictGetInt8([NULL], [NULL], [NULL]);) 2025.11.13 09:22:54.938845 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:54.950415 [ 19606 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 506.64 MiB (attempt to allocate chunk of 8.49 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000b1f4f78 12. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000b1f49e5 13. ./src/Common/Arena.h:321: DB::MixedArenaAllocator<4096ul, Allocator, DB::AlignedArenaAllocator<8ul>, 8ul>::realloc(void*, unsigned long, unsigned long, DB::Arena*) @ 0x0000000020e708c2 14. ./src/Common/PODArray.h:152: void DB::PODArrayBase<8ul, 32ul, DB::MixedArenaAllocator<4096ul, Allocator, DB::AlignedArenaAllocator<8ul>, 8ul>, 0ul, 0ul>::reserveForNextSize(DB::Arena*&) @ 0x0000000020e70454 15. ./src/Common/PODArray.h:428: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000020c8e3b8 16. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000031cad8c3 17. ./build_docker/./src/Interpreters/Aggregator.cpp:1191: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x000000003213c5c3 18. ./build_docker/./src/Interpreters/Aggregator.cpp:992: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned int, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000032135c95 19. ./build_docker/./src/Interpreters/Aggregator.cpp:952: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000031e92104 20. ./build_docker/./src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000031ca8d5b 21. ./build_docker/./src/Interpreters/Aggregator.cpp:1587: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb4455 22. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 23. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:22:54.992251 [ 16233 ] {b2d4d623-f5c6-469d-a541-16a7384e5280} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt8OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 462, line 463) (in query: SELECT dictGetInt8OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.004508 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt8OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:55.063592 [ 16233 ] {5893b957-c882-471d-96f4-9ede387f4f4f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 463, line 464) (in query: SELECT dictGetOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.078570 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:55.140563 [ 16233 ] {8581c82b-11d8-43a9-901e-181c6a43dd03} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 464, line 465) (in query: SELECT dictGetOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.168134 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:55.214832 [ 16233 ] {bffdcad4-5a91-4695-b2ce-84673ec0e6b3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 465, line 466) (in query: SELECT dictGetString([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.226391 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:55.313601 [ 16233 ] {3ad6b9e6-a1a2-4766-ae15-a095c5d59a38} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetStringOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 466, line 467) (in query: SELECT dictGetStringOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.357430 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetStringOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:55.480596 [ 16233 ] {1dc3f5f5-d282-4225-9fb9-762bce192b3f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt16([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 467, line 468) (in query: SELECT dictGetUInt16([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.492506 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt16([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:55.599190 [ 16233 ] {d9631f97-4cea-409d-b2f6-247e83929bf4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt16OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 468, line 469) (in query: SELECT dictGetUInt16OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.612758 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt16OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:55.676537 [ 16233 ] {155a3106-7719-4bad-978e-ef8ac3845b26} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 469, line 470) (in query: SELECT dictGetUInt32([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.686447 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 572.82 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 10670): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:55.688295 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 572.82 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 10670): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:55.693552 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:55.694476 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 562.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:55.708096 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:55.776978 [ 16233 ] {78e236c0-23fb-4606-94ca-b1e3b5a7babe} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 470, line 471) (in query: SELECT dictGetUInt32OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.790055 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:55.847827 [ 16233 ] {e7a126a7-7c42-45ec-8339-6bbe67e082cc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 471, line 472) (in query: SELECT dictGetUInt64([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.863077 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:55.918950 [ 16233 ] {cbfc2105-3d3e-4059-876d-192d34164cef} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 472, line 473) (in query: SELECT dictGetUInt64OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:55.932120 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:56.052558 [ 16233 ] {ae96b989-51a8-44a4-8bdf-beb6d80da8e4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 473, line 474) (in query: SELECT dictGetUInt8([NULL], [NULL], [NULL]);) 2025.11.13 09:22:56.063165 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:56.120476 [ 16233 ] {a40b69ac-a713-429f-8b9e-879a8025dbaf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt8OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 474, line 475) (in query: SELECT dictGetUInt8OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:56.133800 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt8OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:56.317085 [ 16233 ] {e7b9bb08-67f6-48a3-99d6-b9cb57f62a2d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUUID([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 475, line 476) (in query: SELECT dictGetUUID([NULL], [NULL], [NULL]);) 2025.11.13 09:22:56.331852 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUUID([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:56.377251 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_108_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 575.72 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:56.379055 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_108_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 575.72 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:56.408203 [ 2997 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 576.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:56.409273 [ 2997 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 576.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:56.448094 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 575.74 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: (while reading column value8): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9077): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:56.450367 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 575.74 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: (while reading column value8): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9077): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:56.522202 [ 16233 ] {cb1c9beb-56df-494d-8747-ec2e0b951f8a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUUIDOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 476, line 477) (in query: SELECT dictGetUUIDOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:22:56.535139 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUUIDOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:56.681400 [ 16233 ] {ac48ee5c-92d8-4804-ae86-442cc49bbc92} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictHas, expected a string: In scope SELECT dictHas([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 477, line 478) (in query: SELECT dictHas([NULL], [NULL], [NULL]);) 2025.11.13 09:22:56.699231 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictHas, expected a string: In scope SELECT dictHas([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:56.755380 [ 16233 ] {d91c7a10-fc8a-4546-95b3-796ab1f2266c} executeQuery: Code: 43. DB::Exception: Illegal type of first argument of function dictIsIn. Expected String. Actual type Array(Nullable(Nothing)): In scope SELECT dictIsIn([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 478, line 479) (in query: SELECT dictIsIn([NULL], [NULL], [NULL]);) 2025.11.13 09:22:56.767058 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type of first argument of function dictIsIn. Expected String. Actual type Array(Nullable(Nothing)): In scope SELECT dictIsIn([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:56.825024 [ 16233 ] {88317267-80d5-4efd-97d3-6740951c8ebe} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 479, line 480) (in query: SELECT displayName([NULL], [NULL], [NULL]);) 2025.11.13 09:22:56.836307 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:56.897214 [ 16233 ] {b0a0dae6-e57e-412b-af11-c0681e82dedd} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 480, line 481) (in query: SELECT distanceL1([NULL], [NULL], [NULL]);) 2025.11.13 09:22:56.909402 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:56.927904 [ 10170 ] {b3061292-094b-4985-9844-d7aefe9e3bcb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44608) (comment: 02555_davengers_rename_chain.sh) (in query: DROP DATABASE IF EXISTS test_nu5td7bc SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:22:56.935468 [ 10170 ] {b3061292-094b-4985-9844-d7aefe9e3bcb} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:56.964512 [ 16233 ] {41564791-c7fb-4a04-9592-63ed5603fbf9} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 481, line 482) (in query: SELECT distanceL2([NULL], [NULL], [NULL]);) 2025.11.13 09:22:56.978119 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:57.033840 [ 16233 ] {7c3c650f-2b64-4c72-9c73-0141ef003a4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 482, line 483) (in query: SELECT distanceL2Squared([NULL], [NULL], [NULL]);) 2025.11.13 09:22:57.064706 [ 18728 ] {8db4a67a-73ac-4c0d-b343-db1d4f469095} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 545.90 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38868) (comment: 00148_summing_merge_tree_aggregate_function.sql) (query 37, line 83) (in query: insert into summing_merge_tree_aggregate_function select 1, 1, topKWeightedState(2)(1, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 2025.11.13 09:22:57.094086 [ 18728 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 545.90 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:57.117974 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:57.163439 [ 16233 ] {af7e3b84-8f82-4979-a9a4-6b43f288ac68} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 483, line 484) (in query: SELECT distanceLinf([NULL], [NULL], [NULL]);) 2025.11.13 09:22:57.176306 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:57.274614 [ 16233 ] {2626a027-2c5b-4de1-b901-69a58ba823ba} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nullable(Nothing). Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT distanceLp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 484, line 485) (in query: SELECT distanceLp([NULL], [NULL], [NULL]);) 2025.11.13 09:22:57.286872 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nullable(Nothing). Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, BFloat16, Float32, Float64.: In scope SELECT distanceLp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:57.415932 [ 16233 ] {8d26ff1e-2749-4d8e-b682-c4788bb04800} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctDynamicTypes. Expected single argument with type Dynamic, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 485, line 486) (in query: SELECT distinctDynamicTypes([NULL], [NULL], [NULL]);) 2025.11.13 09:22:57.428548 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctDynamicTypes. Expected single argument with type Dynamic, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:57.521772 [ 16233 ] {aeafde30-dca2-4056-8e77-c436746be77d} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPaths. Expected single argument with type JSON, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 486, line 487) (in query: SELECT distinctJSONPaths([NULL], [NULL], [NULL]);) 2025.11.13 09:22:57.543457 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPaths. Expected single argument with type JSON, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:57.593944 [ 16233 ] {d5ccf705-9463-4f5d-ba53-6d7420cd1cfd} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPathsAndTypes. Expected single argument with type JSON, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 487, line 488) (in query: SELECT distinctJSONPathsAndTypes([NULL], [NULL], [NULL]);) 2025.11.13 09:22:57.608194 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function distinctJSONPathsAndTypes. Expected single argument with type JSON, got 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:57.664260 [ 16233 ] {d752824b-1cf9-42d5-bfa8-bfbe06ebdf0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 488, line 489) (in query: SELECT divide([NULL], [NULL], [NULL]);) 2025.11.13 09:22:57.676717 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:57.731290 [ 16233 ] {85404f29-5470-485c-b776-11f0ebbb905d} executeQuery: Code: 43. DB::Exception: Arguments for divideDecimal function must be Decimal: In scope SELECT divideDecimal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 489, line 490) (in query: SELECT divideDecimal([NULL], [NULL], [NULL]);) 2025.11.13 09:22:57.744770 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Arguments for divideDecimal function must be Decimal: In scope SELECT divideDecimal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:22:57.800325 [ 16233 ] {c6beecfd-f56d-404f-be99-e397c2563949} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 490, line 491) (in query: SELECT domain([NULL], [NULL], [NULL]);) 2025.11.13 09:22:57.815184 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:57.829324 [ 3739 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 509.28 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:57.831367 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 509.28 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:58.013273 [ 19606 ] {15ad5786-ad4d-4cb6-bd92-d0a8dcd28805} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53110) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: CREATE TABLE IF NOT EXISTS test_01516_test_1.data3 ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 13313, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 112, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 169350409, compact_parts_max_granules_to_buffer = 188, compact_parts_merge_max_bytes_to_prefetch_part = 66909, merge_max_block_size = 8184, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26983051, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 17, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 35540, primary_key_compress_block_size = 61589, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true AS SELECT * FROM numbers(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:22:58.037688 [ 19606 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:22:58.044436 [ 16233 ] {edccdfde-2499-4f10-8bc3-7eb823b13c8f} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 491, line 492) (in query: SELECT domainRFC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:58.061069 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:58.124835 [ 16605 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:58.125777 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:58.169000 [ 16233 ] {0ab84dd2-7308-4a57-9d39-e856d3b7dfd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 492, line 493) (in query: SELECT domainWithoutWWW([NULL], [NULL], [NULL]);) 2025.11.13 09:22:58.181868 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:58.240460 [ 16233 ] {75fefb61-281a-474e-8921-2381304d7092} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 493, line 494) (in query: SELECT domainWithoutWWWRFC([NULL], [NULL], [NULL]);) 2025.11.13 09:22:58.251957 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:58.315587 [ 16233 ] {01fb38cb-8109-454e-bd78-a6649af545e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 494, line 495) (in query: SELECT dotProduct([NULL], [NULL], [NULL]);) 2025.11.13 09:22:58.332193 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:58.400287 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 526.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:58.407588 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_202_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 526.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:58.408540 [ 3730 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_82_16} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 511.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_81_81_0/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 15): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:58.410247 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_82_16}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 511.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_81_81_0/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 15): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:58.499595 [ 16233 ] {7ee99a11-30a9-4338-8798-d3608633626b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 495, line 496) (in query: SELECT dumpColumnStructure([NULL], [NULL], [NULL]);) 2025.11.13 09:22:58.513828 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:58.547739 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_108_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.33 MiB (attempt to allocate chunk of 1.19 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_100_100_0/data.bin (position: 96951, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 70af4dd27c53ea45b9f931586315ea7182913a000019030300): (while reading column Settings): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_100_100_0/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 454): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 16. ./src/IO/ReadHelpers.h:117: DB::SerializationLowCardinality::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f697089 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:61: DB::SerializationNamed::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6c06fb 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:730: DB::SerializationTuple::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f7e8a8b 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:293: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f5ae089 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:452: DB::SerializationMap::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6b6e8e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:290: DB::MergeTreeReaderCompact::readPrefix(DB::NameAndTypePair const&, std::shared_ptr const&, std::shared_ptr&, std::function const&) @ 0x0000000039e8f707 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:274: DB::MergeTreeReaderCompact::readPrefix(unsigned long, DB::MergeTreeReaderStream&) @ 0x0000000039e8ef62 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:52: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed659b 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:58.549929 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_108_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.33 MiB (attempt to allocate chunk of 1.19 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_100_100_0/data.bin (position: 96951, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 70af4dd27c53ea45b9f931586315ea7182913a000019030300): (while reading column Settings): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_100_100_0/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 454): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 16. ./src/IO/ReadHelpers.h:117: DB::SerializationLowCardinality::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f697089 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:61: DB::SerializationNamed::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6c06fb 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:730: DB::SerializationTuple::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f7e8a8b 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:293: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f5ae089 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:452: DB::SerializationMap::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6b6e8e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:290: DB::MergeTreeReaderCompact::readPrefix(DB::NameAndTypePair const&, std::shared_ptr const&, std::shared_ptr&, std::function const&) @ 0x0000000039e8f707 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:274: DB::MergeTreeReaderCompact::readPrefix(unsigned long, DB::MergeTreeReaderStream&) @ 0x0000000039e8ef62 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:52: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed659b 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:58.585514 [ 16233 ] {dcc26590-2ab1-419b-b062-e247b822574a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 496, line 497) (in query: SELECT dynamicElement([NULL], [NULL], [NULL]);) 2025.11.13 09:22:58.608247 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:58.657952 [ 16233 ] {83f0204f-41f3-4b1e-b5ae-08b1f44242d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 497, line 498) (in query: SELECT dynamicType([NULL], [NULL], [NULL]);) 2025.11.13 09:22:58.670348 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:58.727876 [ 16233 ] {679d1cfe-5661-4c60-85a4-108221218f53} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 498, line 499) (in query: SELECT e([NULL], [NULL], [NULL]);) 2025.11.13 09:22:58.740093 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:58.797684 [ 16233 ] {a609fd69-51c9-4b52-8ed5-6f2796db2c32} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 499, line 500) (in query: SELECT editDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:22:58.897539 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:58.943368 [ 16233 ] {6292f287-5e83-4273-84dd-259755cfe0f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 500, line 501) (in query: SELECT editDistanceUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:22:58.965970 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:59.018413 [ 16233 ] {89a5dabb-3854-4c79-a797-edd28b4c188b} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 501, line 502) (in query: SELECT empty([NULL], [NULL], [NULL]);) 2025.11.13 09:22:59.034000 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:59.084867 [ 16233 ] {3ab075a6-5a7f-4cca-b8eb-38a23bd9ceae} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 502, line 503) (in query: SELECT emptyArrayDate([NULL], [NULL], [NULL]);) 2025.11.13 09:22:59.098345 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:59.098533 [ 16230 ] {0f1e04d5-c161-41df-87a3-48c526fb07eb} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52882) (comment: 00521_multidimensional.sql) (query 4, line 5) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`arr` AS `arr` FROM `test_13`.`multidimensional` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:22:59.113436 [ 16230 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:22:59.117645 [ 6072 ] {883ae7b3-6e4b-447b-afef-16d0c21341e9} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: (total) memory limit exceeded: would use 505.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53096) (comment: 00521_multidimensional.sql) (query 4, line 5) (in query: SELECT * FROM multidimensional;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:22:59.153457 [ 16233 ] {9cad6791-3ee4-495f-949a-57623f029340} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 503, line 504) (in query: SELECT emptyArrayDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:22:59.167462 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:59.258173 [ 16233 ] {2f226b4b-c7d9-44fa-ba29-4e1ccffa1958} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 504, line 505) (in query: SELECT emptyArrayFloat32([NULL], [NULL], [NULL]);) 2025.11.13 09:22:59.261148 [ 6072 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: (total) memory limit exceeded: would use 505.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:22:59.272080 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:59.330435 [ 16233 ] {ee632d9c-3588-4356-bc51-dfa9122e8637} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 505, line 506) (in query: SELECT emptyArrayFloat64([NULL], [NULL], [NULL]);) 2025.11.13 09:22:59.380148 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:59.441577 [ 16233 ] {72d652cf-3522-45c8-a675-fa6cc8390ba9} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 506, line 507) (in query: SELECT emptyArrayInt16([NULL], [NULL], [NULL]);) 2025.11.13 09:22:59.459062 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:59.513181 [ 16233 ] {9036a00d-bfe7-439e-946a-2ccac093e314} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 507, line 508) (in query: SELECT emptyArrayInt32([NULL], [NULL], [NULL]);) 2025.11.13 09:22:59.525778 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:59.631865 [ 16233 ] {6f8132c3-632f-4901-bb94-7bc841fc2d8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 508, line 509) (in query: SELECT emptyArrayInt64([NULL], [NULL], [NULL]);) 2025.11.13 09:22:59.644434 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:59.697083 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 560.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:59.698024 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 560.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:59.702150 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 560.89 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 10670): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:59.703900 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 560.89 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 10670): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:22:59.705207 [ 16233 ] {6e91fe16-6999-4966-b6cd-421c1629ed04} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 509, line 510) (in query: SELECT emptyArrayInt8([NULL], [NULL], [NULL]);) 2025.11.13 09:22:59.719798 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:22:59.915939 [ 16233 ] {8c5ddb05-4f64-41e3-8f5c-1fa112fa11d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 510, line 511) (in query: SELECT emptyArrayString([NULL], [NULL], [NULL]);) 2025.11.13 09:22:59.966134 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.066189 [ 16233 ] {87973985-dab8-445a-8846-46505bd100c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 511, line 512) (in query: SELECT emptyArrayToSingle([NULL], [NULL], [NULL]);) 2025.11.13 09:23:00.078567 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.133881 [ 16233 ] {33eb8235-6b72-44ea-a88d-17450c6f5039} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 512, line 513) (in query: SELECT emptyArrayUInt16([NULL], [NULL], [NULL]);) 2025.11.13 09:23:00.147223 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.268662 [ 16233 ] {5b5ec435-121d-4f9f-986f-1d1944220253} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 513, line 514) (in query: SELECT emptyArrayUInt32([NULL], [NULL], [NULL]);) 2025.11.13 09:23:00.280503 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.348311 [ 16233 ] {fbc5a2bc-3a2d-4868-b47f-8cc5e9b200fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 514, line 515) (in query: SELECT emptyArrayUInt64([NULL], [NULL], [NULL]);) 2025.11.13 09:23:00.360843 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.423255 [ 16233 ] {a11c10d9-c3f4-4ad9-b0e2-c19a2c0ee8c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 515, line 516) (in query: SELECT emptyArrayUInt8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:00.434542 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.493498 [ 16233 ] {3646577c-7146-4632-97f9-3ba849f4dd60} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 516, line 517) (in query: SELECT enabledProfiles([NULL], [NULL], [NULL]);) 2025.11.13 09:23:00.511145 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.526385 [ 16887 ] {450574ba-9a59-4032-a1a6-674a08988f4a} executeQuery: Code: 59. DB::Exception: Invalid type for filter in HAVING: Nothing. In query SELECT * FROM numbers(4) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53176) (comment: 01548_with_totals_having.sql) (query 1, line 1) (in query: SELECT * FROM numbers(4) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002eb21d17 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003054fa9f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:77: DB::validateFilters(std::shared_ptr const&) @ 0x000000003054eebf 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5802: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe18 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:23:00.535141 [ 16887 ] {} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in HAVING: Nothing. In query SELECT * FROM numbers(4) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([]). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x000000002eb21d17 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:50: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x000000003054fa9f 5. ./build_docker/./src/Analyzer/ValidationUtils.cpp:77: DB::validateFilters(std::shared_ptr const&) @ 0x000000003054eebf 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5802: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe18 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:23:00.568081 [ 16233 ] {1c1df13d-4fd0-41d7-a53c-8361de394346} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 517, line 518) (in query: SELECT enabledRoles([NULL], [NULL], [NULL]);) 2025.11.13 09:23:00.582228 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.641474 [ 16233 ] {52c041c8-0cad-4aeb-9696-6f2ea9c49046} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 518, line 519) (in query: SELECT encodeURLComponent([NULL], [NULL], [NULL]);) 2025.11.13 09:23:00.655603 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.665245 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 569.27 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:00.667777 [ 16605 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 567.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:00.699055 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 567.89 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:00.700983 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 567.89 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:00.711707 [ 16233 ] {73034c45-80e7-4f5c-b84e-7e4dcf676f43} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 519, line 520) (in query: SELECT encodeURLFormComponent([NULL], [NULL], [NULL]);) 2025.11.13 09:23:00.725890 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.772258 [ 16605 ] {c0724fa5-b45b-4114-8e34-307275a02aa8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44648) (comment: 00070_insert_fewer_columns_http.sh) (in query: DROP DATABASE IF EXISTS test_77zt36em SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:23:00.778936 [ 16605 ] {c0724fa5-b45b-4114-8e34-307275a02aa8} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:00.785186 [ 16233 ] {4b18e442-a7c9-4f2b-a391-aa0ce83ef0f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 520, line 521) (in query: SELECT encodeXMLComponent([NULL], [NULL], [NULL]);) 2025.11.13 09:23:00.797665 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:00.910355 [ 16233 ] {ea51b243-4f70-4468-af0b-097c283481f9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: Array(Nullable(Nothing)): In scope SELECT encrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 521, line 522) (in query: SELECT encrypt([NULL], '[HIDDEN]')) 2025.11.13 09:23:00.923408 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: Array(Nullable(Nothing)): In scope SELECT encrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:00.989718 [ 16233 ] {f2ed0a48-6b6c-43bf-83cd-27eec206cd28} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 522, line 523) (in query: SELECT endsWith([NULL], [NULL], [NULL]);) 2025.11.13 09:23:01.004385 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:01.065082 [ 16233 ] {2e470200-4a02-4021-bba0-2c20599c6222} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 523, line 524) (in query: SELECT endsWithUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:01.078055 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:01.189878 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 515.04 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:01.191850 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 515.04 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:01.348929 [ 16233 ] {c1e9fac5-51ac-48be-a1de-83b26b850804} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 525, line 526) (in query: SELECT equals([NULL], [NULL], [NULL]);) 2025.11.13 09:23:01.370138 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:01.485152 [ 16233 ] {9b25213a-1aa0-45d4-938d-ec94a50ad81e} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 526, line 527) (in query: SELECT erf([NULL], [NULL], [NULL]);) 2025.11.13 09:23:01.502179 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:01.560262 [ 16233 ] {fa2263ed-6ea4-45da-9393-35fa4a3f780e} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 527, line 528) (in query: SELECT erfc([NULL], [NULL], [NULL]);) 2025.11.13 09:23:01.584872 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:01.680970 [ 16233 ] {d6719ce8-4cff-4e3c-a81f-6c6e41937d96} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 528, line 529) (in query: SELECT errorCodeToName([NULL], [NULL], [NULL]);) 2025.11.13 09:23:01.708362 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:01.721602 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_108_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 572.66 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column Settings): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_98_98_0/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 273): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037ae594e 12. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037c869b9 13. ./src/Columns/ColumnsCommon.h:121: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037af981f 14. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037af962e 15. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:268: DB::ColumnLowCardinality::insertRangeFromDictionaryEncodedColumn(DB::IColumn const&, DB::IColumn const&) @ 0x0000000037540706 16. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:612: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69cda4 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 27. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:01.723814 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_108_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 572.66 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column Settings): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_98_98_0/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 273): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037ae594e 12. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037c869b9 13. ./src/Columns/ColumnsCommon.h:121: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037af981f 14. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037af962e 15. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:268: DB::ColumnLowCardinality::insertRangeFromDictionaryEncodedColumn(DB::IColumn const&, DB::IColumn const&) @ 0x0000000037540706 16. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:612: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69cda4 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 27. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:01.753542 [ 16233 ] {917d62d6-bbf0-4e4d-8925-c550e2b0e6c2} executeQuery: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 529, line 530) (in query: SELECT estimateCompressionRatio([NULL], [NULL], [NULL]);) 2025.11.13 09:23:01.768131 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function estimateCompressionRatio requires exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:01.771923 [ 16887 ] {b4b03654-910e-4f50-b082-0cb7e2c26b49} executeQuery: Code: 44. DB::Exception: Having clause cannot contain arrayJoin. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53176) (comment: 01548_with_totals_having.sql) (query 2, line 2) (in query: SELECT * FROM numbers(4) GROUP BY number WITH TOTALS HAVING sum(number) <= arrayJoin([3, 2, 1, 0]) ORDER BY number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:189: DB::TotalsHavingTransform::transform(DB::Chunk&) @ 0x000000003bcee2c0 5. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 6. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 7. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:146: DB::TotalsHavingTransform::work() @ 0x000000003bceb04e 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:23:01.793421 [ 16887 ] {} TCPHandler: Code: 44. DB::Exception: Having clause cannot contain arrayJoin. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:189: DB::TotalsHavingTransform::transform(DB::Chunk&) @ 0x000000003bcee2c0 5. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 6. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 7. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:146: DB::TotalsHavingTransform::work() @ 0x000000003bceb04e 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:23:01.931116 [ 16233 ] {8b02e4ad-70f9-4fd2-b097-0aedc7be29c5} executeQuery: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 530, line 531) (in query: SELECT evalMLMethod([NULL], [NULL], [NULL]);) 2025.11.13 09:23:02.028413 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:02.105136 [ 19621 ] {e3b23b01-9053-492d-bd59-fcfcd5e9a74b} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 573.04 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION materialize(_CAST('{"k1": 1, "k2": 2}', JSON) :: 2) -> materialize(_CAST('{"k1": 1, "k2": 2}', JSON)) JSON : 0'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53214) (comment: 01825_new_type_json_missed_values.sql) (query 5, line 13) (in query: INSERT INTO t_json SELECT number, '{"k1": 1, "k2": 2}' FROM numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnArray::replicateString(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370af536 12. ./build_docker/./src/Columns/ColumnArray.cpp:1108: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370ae2c5 13. ./build_docker/./src/Columns/ColumnArray.cpp:1349: DB::ColumnArray::replicateTuple(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370b2c6d 14. ./build_docker/./src/Columns/ColumnArray.cpp:1114: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370ae533 15. ./build_docker/./src/Columns/ColumnObject.cpp:1163: DB::ColumnObject::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003763d4b5 16. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x00000000371b3ac4 17. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x00000000371b7e0e 18. ./src/Functions/materialize.h:59: DB::FunctionMaterialize::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000302db4e0 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14f623 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:23:02.141505 [ 19621 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 573.04 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION materialize(_CAST('{"k1": 1, "k2": 2}', JSON) :: 2) -> materialize(_CAST('{"k1": 1, "k2": 2}', JSON)) JSON : 0'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnArray::replicateString(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370af536 12. ./build_docker/./src/Columns/ColumnArray.cpp:1108: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370ae2c5 13. ./build_docker/./src/Columns/ColumnArray.cpp:1349: DB::ColumnArray::replicateTuple(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370b2c6d 14. ./build_docker/./src/Columns/ColumnArray.cpp:1114: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000370ae533 15. ./build_docker/./src/Columns/ColumnObject.cpp:1163: DB::ColumnObject::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003763d4b5 16. ./build_docker/./src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x00000000371b3ac4 17. ./src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x00000000371b7e0e 18. ./src/Functions/materialize.h:59: DB::FunctionMaterialize::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000302db4e0 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14f623 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:23:02.174730 [ 16233 ] {be9f37f8-ca10-43d8-ba91-69cc14d04139} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 531, line 532) (in query: SELECT exp([NULL], [NULL], [NULL]);) 2025.11.13 09:23:02.187879 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:02.248070 [ 16233 ] {86a2b325-f11a-47ac-af10-fb3e8ce52e50} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 532, line 533) (in query: SELECT exp10([NULL], [NULL], [NULL]);) 2025.11.13 09:23:02.260526 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:02.318411 [ 16233 ] {e566c206-bc29-460d-ba31-aca8b1b91ce8} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 533, line 534) (in query: SELECT exp2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:02.330242 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:02.397214 [ 16233 ] {3a2487bc-521b-48eb-8d3f-5557283d601a} executeQuery: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 534, line 535) (in query: SELECT exponentialMovingAverage([NULL], [NULL], [NULL]);) 2025.11.13 09:23:02.411906 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:02.561056 [ 16233 ] {af63c4ea-b842-455a-bf01-7a395408201a} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 535, line 536) (in query: SELECT exponentialTimeDecayedAvg([NULL], [NULL], [NULL]);) 2025.11.13 09:23:02.574165 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:02.636963 [ 16233 ] {d9f40e22-2f9d-4f1c-b373-9ff4dce754a1} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 536, line 537) (in query: SELECT exponentialTimeDecayedCount([NULL], [NULL], [NULL]);) 2025.11.13 09:23:02.648873 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:02.739150 [ 16233 ] {b86c59fc-046d-4faa-96d2-91b8a3810e9b} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 537, line 538) (in query: SELECT exponentialTimeDecayedMax([NULL], [NULL], [NULL]);) 2025.11.13 09:23:02.750462 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:02.813948 [ 16233 ] {c5e8e580-a0db-42d0-8faa-62e48f1b6587} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 538, line 539) (in query: SELECT exponentialTimeDecayedSum([NULL], [NULL], [NULL]);) 2025.11.13 09:23:02.829471 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:02.912440 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 578.51 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column value8): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9077): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:02.914222 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 578.51 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column value8): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9077): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:02.931033 [ 16233 ] {7bd2d138-8c40-4334-a8c6-c959863f96c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 539, line 540) (in query: SELECT extract([NULL], [NULL], [NULL]);) 2025.11.13 09:23:02.944835 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:03.004641 [ 16233 ] {b9b7a0b5-b451-46d4-ba05-07978ea7f784} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 540, line 541) (in query: SELECT extractAll([NULL], [NULL], [NULL]);) 2025.11.13 09:23:03.015837 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:03.072231 [ 16233 ] {4b73860c-0a6f-449a-acaa-02be350b567d} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 541, line 542) (in query: SELECT extractAllGroups([NULL], [NULL], [NULL]);) 2025.11.13 09:23:03.083447 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:03.146947 [ 16233 ] {8b4230a3-f1d2-4985-a166-7f6daa7f24ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 542, line 543) (in query: SELECT extractAllGroupsHorizontal([NULL], [NULL], [NULL]);) 2025.11.13 09:23:03.160493 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:03.221877 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 2502 entries up to offset 416913: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.16 MiB (attempt to allocate chunk of 4.19 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:03.276023 [ 16233 ] {0e01a662-9b7d-4255-904a-f1210500a08d} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 543, line 544) (in query: SELECT extractAllGroupsVertical([NULL], [NULL], [NULL]);) 2025.11.13 09:23:03.292911 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:03.315861 [ 3730 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_78_83_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 497.68 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_81_81_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 17): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:03.317792 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_78_83_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 497.68 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_81_81_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 17): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:03.435761 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_108_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.90 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:03.437652 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_108_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.90 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:03.540475 [ 16233 ] {b09d2382-97d5-47a2-bedb-6e7602155727} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 544, line 545) (in query: SELECT extractGroups([NULL], [NULL], [NULL]);) 2025.11.13 09:23:03.575938 [ 16605 ] {55d7025f-e65f-4cc4-b5e3-44ddb70f15b2} executeQuery: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:33070): While executing NumbersRange. (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33070) (comment: 03307_progress_http_asap.sh) (in query: SELECT count() FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:116: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x000000001fcafaa9 4. ./src/Server/HTTP/HTTPServerResponse.h:198: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000003af4d308 5. ./src/Server/HTTP/HTTPServerResponse.h:166: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003af464df 6. DB::WriteBuffer::next() @ 0x0000000008c37ea1 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:126: DB::IOutputFormat::flushImpl() @ 0x000000003b22823a 8. ./src/Processors/Formats/OutputFormatWithUTF8ValidationAdaptor.h:36: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::flushImpl() @ 0x000000003b5d2d5c 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:211: DB::IOutputFormat::onProgress(DB::Progress const&) @ 0x000000003b229f15 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1864: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>)::$_2, void (DB::Progress const&)>>(std::__function::__policy_storage const*, DB::Progress const&) @ 0x000000003385211b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f266203 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fdc97 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:03.641015 [ 3733 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.96 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:03.643927 [ 16605 ] {55d7025f-e65f-4cc4-b5e3-44ddb70f15b2} DynamicQueryHandler: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:33070): While executing NumbersRange. (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:116: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x000000001fcafaa9 4. ./src/Server/HTTP/HTTPServerResponse.h:198: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000003af4d308 5. ./src/Server/HTTP/HTTPServerResponse.h:166: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000003af464df 6. DB::WriteBuffer::next() @ 0x0000000008c37ea1 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:126: DB::IOutputFormat::flushImpl() @ 0x000000003b22823a 8. ./src/Processors/Formats/OutputFormatWithUTF8ValidationAdaptor.h:36: DB::RowOutputFormatWithExceptionHandlerAdaptor, bool>::flushImpl() @ 0x000000003b5d2d5c 9. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:211: DB::IOutputFormat::onProgress(DB::Progress const&) @ 0x000000003b229f15 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1864: void std::__function::__policy_invoker::__call_impl[abi:ne190107], std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>)::$_2, void (DB::Progress const&)>>(std::__function::__policy_storage const*, DB::Progress const&) @ 0x000000003385211b 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f266203 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fdc97 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:03.644226 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.96 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:03.659418 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:03.782108 [ 16233 ] {a7e48726-f7c1-40ff-8dde-4607d5881b88} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 545, line 546) (in query: SELECT extractKeyValuePairs([NULL], [NULL], [NULL]);) 2025.11.13 09:23:03.794784 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:03.963873 [ 16233 ] {41b9708b-1149-46bc-a381-bb0d0ad01aee} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 546, line 547) (in query: SELECT extractKeyValuePairsWithEscaping([NULL], [NULL], [NULL]);) 2025.11.13 09:23:04.019508 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:04.084562 [ 16233 ] {db763c21-2152-4856-a2ae-beab3a0454c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 547, line 548) (in query: SELECT extractTextFromHTML([NULL], [NULL], [NULL]);) 2025.11.13 09:23:04.099887 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:04.158748 [ 16233 ] {5a9030e7-6f7e-4682-8681-2fb75cc19cc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 548, line 549) (in query: SELECT extractURLParameter([NULL], [NULL], [NULL]);) 2025.11.13 09:23:04.163484 [ 16605 ] {55d7025f-e65f-4cc4-b5e3-44ddb70f15b2} bool DB::WriteBufferFromHTTPServerResponse::cancelWithException(HTTPServerRequest &, int, const std::string &, WriteBuffer *): Failed to send exception to the response write buffer.: Code: 236. DB::Exception: Write buffer has been canceled. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:250: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000003af491be 5. ./build_docker/./src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace747b 6. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 7. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:04.169843 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:04.226859 [ 16233 ] {898a8031-31ab-4231-83de-7c66cfc4b706} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 549, line 550) (in query: SELECT extractURLParameterNames([NULL], [NULL], [NULL]);) 2025.11.13 09:23:04.242926 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:04.292991 [ 16233 ] {08edb248-c083-4671-a949-d2e567dc4cc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 550, line 551) (in query: SELECT extractURLParameters([NULL], [NULL], [NULL]);) 2025.11.13 09:23:04.303882 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:04.367113 [ 16233 ] {10ecc332-b159-4eba-9d7e-3fc653ab63f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 551, line 552) (in query: SELECT factorial([NULL], [NULL], [NULL]);) 2025.11.13 09:23:04.428903 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:04.551470 [ 16605 ] {9fd66722-ed3e-4082-9ece-f1bdf8f8f23f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44694) (comment: 02024_join_on_or_long.gen.sql) (in query: DROP DATABASE IF EXISTS test_69caz0xx SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:23:04.559558 [ 16605 ] {9fd66722-ed3e-4082-9ece-f1bdf8f8f23f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:04.803734 [ 16233 ] {867463d9-f63e-4a59-826e-4b0111357454} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 554, line 555) (in query: SELECT file([NULL], [NULL], [NULL]);) 2025.11.13 09:23:04.815900 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:04.965137 [ 16233 ] {2ccbaa4c-d992-4e16-a843-3978531ff81c} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemAvailable should be 0 or 1: In scope SELECT filesystemAvailable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 555, line 556) (in query: SELECT filesystemAvailable([NULL], [NULL], [NULL]);) 2025.11.13 09:23:04.980234 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemAvailable should be 0 or 1: In scope SELECT filesystemAvailable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:05.036922 [ 16233 ] {d4a3a889-0c40-4927-a756-596221b6016f} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemCapacity should be 0 or 1: In scope SELECT filesystemCapacity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 556, line 557) (in query: SELECT filesystemCapacity([NULL], [NULL], [NULL]);) 2025.11.13 09:23:05.043571 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 530.56 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:05.045472 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 530.56 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:05.117207 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemCapacity should be 0 or 1: In scope SELECT filesystemCapacity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:05.240653 [ 16233 ] {4488715e-084f-4956-bcb5-7ae1086da05c} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemUnreserved should be 0 or 1: In scope SELECT filesystemUnreserved([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 557, line 558) (in query: SELECT filesystemUnreserved([NULL], [NULL], [NULL]);) 2025.11.13 09:23:05.253881 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemUnreserved should be 0 or 1: In scope SELECT filesystemUnreserved([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:05.497762 [ 16233 ] {6562934d-c3b4-478f-82a2-275b793abec9} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 558, line 559) (in query: SELECT finalizeAggregation([NULL], [NULL], [NULL]);) 2025.11.13 09:23:05.511636 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:05.578009 [ 16233 ] {b730d16a-3c5d-4760-8eb3-05df01265d28} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 559, line 560) (in query: SELECT firstLine([NULL], [NULL], [NULL]);) 2025.11.13 09:23:05.591285 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:05.845262 [ 16233 ] {fb4251ab-81c0-460c-a494-73586e07b337} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 560, line 561) (in query: SELECT firstSignificantSubdomain([NULL], [NULL], [NULL]);) 2025.11.13 09:23:05.858462 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:05.920199 [ 16233 ] {cc196a1a-8d5f-48f8-a3ee-130f7c3d6486} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 561, line 562) (in query: SELECT firstSignificantSubdomainCustom([NULL], [NULL], [NULL]);) 2025.11.13 09:23:05.934808 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:05.992735 [ 16233 ] {617981c5-248a-4fc4-b49c-1f677e0dfc94} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 562, line 563) (in query: SELECT firstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.004525 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:06.078590 [ 16233 ] {f02fe2a9-85df-4c46-bddd-7bf2b371ac7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 563, line 564) (in query: SELECT firstSignificantSubdomainRFC([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.089935 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:06.185254 [ 16233 ] {e45bc041-392d-4121-b03d-e73df8ba3340} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 564, line 565) (in query: SELECT firstValueRespectNulls([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.185810 [ 16215 ] {9025111a-8bf9-4ef8-9a31-37befeb03e1c} executeQuery: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60184) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 5, line 9) (in query: SELECT ignore(toFixedString('Lambda as function parameter', 28), toNullable(28), ignore(8)), sum(marks) FROM system.parts WHERE database = currentDatabase() GROUP BY GROUPING SETS ((2)) FORMAT Null settings optimize_injective_functions_in_group_by=1, optimize_group_by_function_keys=1, group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003056088b 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000003056104b 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000030551fd6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:23:06.195827 [ 16215 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003056088b 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000003056104b 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000030551fd6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:23:06.197769 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:06.254819 [ 16233 ] {a9edeba5-8f29-48f7-8e97-992f8d8cb719} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 565, line 566) (in query: SELECT first_value([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.268412 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:06.332423 [ 16233 ] {d0041ed4-41c0-41e7-a949-d282de2a0f41} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 566, line 567) (in query: SELECT first_value_respect_nulls([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.345926 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:06.402064 [ 16233 ] {c991d17b-8994-4203-957e-d29eeb8a2c2a} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Array(Nullable(Nothing)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 567, line 568) (in query: SELECT flameGraph([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.413767 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Array(Nullable(Nothing)). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:06.471718 [ 16233 ] {825a8578-7d34-40ce-8a19-6b016de0f0a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 568, line 569) (in query: SELECT flatten([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.476704 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 539.29 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:06.478607 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 539.29 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:06.483931 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:06.562024 [ 16233 ] {acc8f7c2-a2ee-4ae8-96b7-e941d6605531} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 569, line 570) (in query: SELECT flattenTuple([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.574099 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:06.637741 [ 16233 ] {bedd4e76-4c18-4e18-9a0e-212515ebcdf3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT floor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 570, line 571) (in query: SELECT floor([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.649107 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT floor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:06.707404 [ 16605 ] {88597df5-8a9c-45a2-bba0-c279bd770ae7} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed: While processing SELECT id FROM `03161_table` WHERE f AND ((NOT f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60202) (comment: 03161_cnf_reduction.sql) (query 5, line 9) (in query: EXPLAIN SYNTAX SELECT id FROM 03161_table WHERE f AND (NOT(f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:41: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000032da638d 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:3329: DB::InterpreterSelectQuery::initSettings() @ 0x0000000032b2c306 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:521: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b12083 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:486: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b104ae 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:303: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b0fd18 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000032a9749d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97ef6 15. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 16. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 17. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000032a8314d 18. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000032a7c4c4 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:23:06.709902 [ 16233 ] {d4bc9c2b-4e78-4362-848f-954109a80e2a} executeQuery: Code: 170. DB::Exception: Bad get: has Array, requested String: In scope SELECT format([NULL], [NULL], [NULL]). (BAD_GET) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 571, line 572) (in query: SELECT format([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.719175 [ 16605 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed: While processing SELECT id FROM `03161_table` WHERE f AND ((NOT f) OR f) SETTINGS convert_query_to_cnf = 1, optimize_using_constraints = 1, enable_analyzer = 1. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:41: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000032da638d 9. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:3329: DB::InterpreterSelectQuery::initSettings() @ 0x0000000032b2c306 10. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:521: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b12083 11. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:486: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::optional, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000032b104ae 12. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:303: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032b0fd18 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000032a9749d 14. ./src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97ef6 15. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 16. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000032a97f01 17. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000032a8314d 18. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000032a7c4c4 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:23:06.722857 [ 16233 ] {} TCPHandler: Code: 170. DB::Exception: Bad get: has Array, requested String: In scope SELECT format([NULL], [NULL], [NULL]). (BAD_GET) 2025.11.13 09:23:06.829956 [ 16233 ] {6dbae5a6-018a-4a72-bb0c-a9509365a9ef} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 572, line 573) (in query: SELECT formatDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.842115 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:06.913745 [ 16233 ] {d5e64a94-25dc-4f3d-8487-26200d2da68b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTimeInJodaSyntax. Should be a date or a date with time: In scope SELECT formatDateTimeInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 573, line 574) (in query: SELECT formatDateTimeInJodaSyntax([NULL], [NULL], [NULL]);) 2025.11.13 09:23:06.925421 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTimeInJodaSyntax. Should be a date or a date with time: In scope SELECT formatDateTimeInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:06.985682 [ 16233 ] {0ed8235c-6773-4a5e-a1e0-9956074156fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 574, line 575) (in query: SELECT formatQuery([NULL], [NULL], [NULL]);) 2025.11.13 09:23:07.003152 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:07.057744 [ 16233 ] {13723a5b-01c4-42e7-a79b-08d3e473d1b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 575, line 576) (in query: SELECT formatQueryOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:07.079757 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:07.144379 [ 16233 ] {7c041ea2-39d2-4157-a79e-0ab243ee1b68} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 576, line 577) (in query: SELECT formatQuerySingleLine([NULL], [NULL], [NULL]);) 2025.11.13 09:23:07.160057 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:07.248517 [ 16233 ] {71f61cbd-9e04-496b-887b-841ac34d7444} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 577, line 578) (in query: SELECT formatQuerySingleLineOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:07.263418 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:07.332382 [ 16233 ] {27b66960-ad0a-4145-ac85-46e89c33cac7} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 578, line 579) (in query: SELECT formatReadableDecimalSize([NULL], [NULL], [NULL]);) 2025.11.13 09:23:07.348727 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:07.427080 [ 16233 ] {1351c0fe-7214-4f4b-90f3-4efe64966980} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 579, line 580) (in query: SELECT formatReadableQuantity([NULL], [NULL], [NULL]);) 2025.11.13 09:23:07.444120 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:07.450845 [ 3739 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 583.48 MiB (attempt to allocate chunk of 1.90 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/data.bin (position: 344309, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 059c3661bf433bb5def601146d9ea9f382a0f3020000001000): (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9077): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:07.452608 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 583.48 MiB (attempt to allocate chunk of 1.90 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/data.bin (position: 344309, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 059c3661bf433bb5def601146d9ea9f382a0f3020000001000): (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9077): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:07.586004 [ 16233 ] {f4aa433d-7e66-42b2-9af5-c00eaa082833} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 580, line 581) (in query: SELECT formatReadableSize([NULL], [NULL], [NULL]);) 2025.11.13 09:23:07.605595 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:07.785339 [ 16233 ] {5f3835da-f209-4519-b2f1-d69c8e5bb952} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nullable(Nothing)) as time delta: In scope SELECT formatReadableTimeDelta([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 581, line 582) (in query: SELECT formatReadableTimeDelta([NULL], [NULL], [NULL]);) 2025.11.13 09:23:07.872071 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nullable(Nothing)) as time delta: In scope SELECT formatReadableTimeDelta([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:07.908884 [ 3724 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 569.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:07.910962 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_203_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 569.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:07.920647 [ 16233 ] {cc0d8a5d-c25c-46c1-a93d-9621acf62a5b} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 582, line 583) (in query: SELECT formatRow([NULL], [NULL], [NULL]);) 2025.11.13 09:23:07.995771 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:08.046828 [ 16233 ] {644793ce-8ef3-4cff-ac1d-4406179870b8} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 583, line 584) (in query: SELECT formatRowNoNewline([NULL], [NULL], [NULL]);) 2025.11.13 09:23:08.061115 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:08.119809 [ 16233 ] {c7773f70-651f-4291-92a2-066c24156778} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 584, line 585) (in query: SELECT fragment([NULL], [NULL], [NULL]);) 2025.11.13 09:23:08.134498 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:08.186335 [ 16233 ] {ed80dc2f-6202-40be-ae38-c6c0e8f90a1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 585, line 586) (in query: SELECT fromDaysSinceYearZero([NULL], [NULL], [NULL]);) 2025.11.13 09:23:08.202177 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:08.254658 [ 16233 ] {b09a2af1-dab3-4bdd-aafd-5cf9a7f449bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 586, line 587) (in query: SELECT fromDaysSinceYearZero32([NULL], [NULL], [NULL]);) 2025.11.13 09:23:08.267990 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:08.336048 [ 16233 ] {1f4d4c5b-dbb2-40e2-bd70-bda29df262cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 587, line 588) (in query: SELECT fromModifiedJulianDay([NULL], [NULL], [NULL]);) 2025.11.13 09:23:08.351496 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:08.411157 [ 16233 ] {7f2d7b58-69f6-4176-b7f7-1401fd1a4a77} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 588, line 589) (in query: SELECT fromModifiedJulianDayOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:08.422981 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:08.481586 [ 16233 ] {e527038c-741c-446f-9516-53e135b37611} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 589, line 590) (in query: SELECT fromUTCTimestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:23:08.576784 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:08.636944 [ 16233 ] {ffedb340-7f8e-40e6-ab3d-2158d40dcac2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestamp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 590, line 591) (in query: SELECT fromUnixTimestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:23:08.648139 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestamp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:08.707978 [ 16233 ] {f6a8cd55-926a-4673-9fa1-f1b048066a49} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 591, line 592) (in query: SELECT fromUnixTimestamp64Micro([NULL], [NULL], [NULL]);) 2025.11.13 09:23:08.725007 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:08.848195 [ 16233 ] {e72dc39d-a11f-4047-800f-5979a1e9b855} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 592, line 593) (in query: SELECT fromUnixTimestamp64Milli([NULL], [NULL], [NULL]);) 2025.11.13 09:23:08.860660 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:09.137050 [ 16233 ] {af2b11fa-a559-43c8-92e4-67c43eff26a9} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 593, line 594) (in query: SELECT fromUnixTimestamp64Nano([NULL], [NULL], [NULL]);) 2025.11.13 09:23:09.162585 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:09.213845 [ 16233 ] {56198222-f8e5-46ff-a399-5cf5e8567659} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Second takes one or two arguments: In scope SELECT fromUnixTimestamp64Second([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 594, line 595) (in query: SELECT fromUnixTimestamp64Second([NULL], [NULL], [NULL]);) 2025.11.13 09:23:09.227181 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Second takes one or two arguments: In scope SELECT fromUnixTimestamp64Second([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:09.259414 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_204_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 626.62 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:09.261181 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_204_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 626.62 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:09.290022 [ 16233 ] {cf8f2289-137d-4a2d-8e18-f47ea916d969} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestampInJodaSyntax when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestampInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 595, line 596) (in query: SELECT fromUnixTimestampInJodaSyntax([NULL], [NULL], [NULL]);) 2025.11.13 09:23:09.303101 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestampInJodaSyntax when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestampInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:09.467946 [ 16233 ] {08a0537e-4d22-4542-8fdb-6e856dffe60a} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 596, line 597) (in query: SELECT from_utc_timestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:23:09.503552 [ 16215 ] {a1064afb-6b11-4018-9718-f7b1b9a4da2e} executeQuery: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60184) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 15, line 49) (in query: SELECT count('Lambda as function parameter') AS c FROM (SELECT ignore(ignore('Lambda as function parameter', 28, 28, 28, 28, 28, 28), 28), materialize('Lambda as function parameter'), 28, 28, 'world', 5 FROM system.numbers WHERE ignore(materialize('Lambda as function parameter'), materialize(toLowCardinality(28)), 28, 28, 28, 28, toUInt128(28)) LIMIT 2) GROUP BY GROUPING SETS ((toLowCardinality(0)), (toLowCardinality(toNullable(28))), (1)) HAVING nullIf(c, 10) < 50 ORDER BY c ASC NULLS FIRST settings group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003056088b 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000003056104b 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000030551fd6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:23:09.512540 [ 16215 ] {} TCPHandler: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000d36ceed 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000003056088b 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305606a5 7. ./build_docker/./src/Analyzer/AggregationUtils.cpp:103: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x000000003056104b 8. ./build_docker/./src/Analyzer/ValidationUtils.cpp:278: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x0000000030551fd6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:23:09.517139 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:09.576280 [ 16233 ] {d3c69ea9-5546-4aff-8a8d-936595298258} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 597, line 598) (in query: SELECT fullHostName([NULL], [NULL], [NULL]);) 2025.11.13 09:23:09.594236 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:09.614577 [ 18106 ] {16a1beb4-dd68-4522-855c-cbd1e911f321} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/store/ae4/ae448d0b-9cac-4435-90e0-68b7c811f0e3//data.TSV doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60298) (comment: 00832_storage_file_lock.sql) (query 3, line 3) (in query: SELECT * FROM file;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038521118 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:23:09.623784 [ 18106 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/store/ae4/ae448d0b-9cac-4435-90e0-68b7c811f0e3//data.TSV doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038521118 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:23:09.667659 [ 16233 ] {469a8b9d-c0ef-4a70-aa8a-0f2c237ed7b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 598, line 599) (in query: SELECT fuzzBits([NULL], [NULL], [NULL]);) 2025.11.13 09:23:09.687279 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:10.018457 [ 16233 ] {8965f852-f1cb-4ed8-bb10-7aa5811a4915} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 600, line 601) (in query: SELECT gcd([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.034060 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:10.096470 [ 16233 ] {02927a5f-808f-4176-8dec-2a878548b532} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 601, line 602) (in query: SELECT generateRandomStructure([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.123038 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:10.197042 [ 16233 ] {5ba17f2b-7630-42a1-9f3b-d33af21c9b64} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 3, should be 1: In scope SELECT generateSerialID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 602, line 603) (in query: SELECT generateSerialID([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.222514 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateSerialID doesn't match: passed 3, should be 1: In scope SELECT generateSerialID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:10.267564 [ 16233 ] {dce54a43-5c45-4a7b-b150-95adfffade4e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 603, line 604) (in query: SELECT generateSnowflakeID([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.280617 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateSnowflakeID'. Expected 2 optional arguments, got 3 arguments: In scope SELECT generateSnowflakeID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:10.338452 [ 16233 ] {58d68622-c61e-498b-bc63-40027728a83d} executeQuery: Code: 34. DB::Exception: Number of arguments for function generateULID doesn't match: passed 3, should be 0 or 1.: In scope SELECT generateULID([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 604, line 605) (in query: SELECT generateULID([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.379899 [ 16233 ] {} TCPHandler: Code: 34. DB::Exception: Number of arguments for function generateULID doesn't match: passed 3, should be 0 or 1.: In scope SELECT generateULID([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.11.13 09:23:10.466952 [ 16233 ] {d230bebb-58e6-44ba-addb-34a5770c7fde} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 605, line 606) (in query: SELECT generateUUIDv4([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.484124 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:10.535528 [ 16233 ] {56b609d7-8ef4-4a1a-ba9a-33c63c096c4c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 606, line 607) (in query: SELECT generateUUIDv7([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.550488 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:10.603604 [ 16233 ] {0af6b4aa-bcfe-47df-ab0d-0f612d3e217d} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 607, line 608) (in query: SELECT geoDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.616223 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:10.673660 [ 16233 ] {af39e451-4bfd-413d-bf0e-e2d0a1200639} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function geoToH3. Must be Float64: In scope SELECT geoToH3([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 608, line 609) (in query: SELECT geoToH3([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.690298 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function geoToH3. Must be Float64: In scope SELECT geoToH3([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:10.748121 [ 16233 ] {c1e54882-c2ca-4cbb-86fc-a6c88f12d5dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 609, line 610) (in query: SELECT geoToS2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.759376 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:10.839743 [ 16233 ] {f51eff06-855a-4051-beab-c4b5e15470c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 610, line 611) (in query: SELECT geohashDecode([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.864891 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:10.967820 [ 16233 ] {f7379845-d1d8-4771-bf00-de38c21c551e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'longitude' to function 'geohashEncode'. Expected: Float*, got: Array(Nullable(Nothing)): In scope SELECT geohashEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 611, line 612) (in query: SELECT geohashEncode([NULL], [NULL], [NULL]);) 2025.11.13 09:23:10.983131 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'longitude' to function 'geohashEncode'. Expected: Float*, got: Array(Nullable(Nothing)): In scope SELECT geohashEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:11.039047 [ 16233 ] {262078b8-a1d3-4e7e-9dc5-af354c9af8a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 612, line 613) (in query: SELECT geohashesInBox([NULL], [NULL], [NULL]);) 2025.11.13 09:23:11.114918 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:11.173980 [ 16233 ] {c6bce57e-2a61-4384-a1c5-80b2ac22bd1a} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 613, line 614) (in query: SELECT getClientHTTPHeader([NULL], [NULL], [NULL]);) 2025.11.13 09:23:11.190373 [ 16233 ] {} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.11.13 09:23:11.241067 [ 16233 ] {b9303cee-2b1e-48c0-9fc4-95b5307171fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 614, line 615) (in query: SELECT getMacro([NULL], [NULL], [NULL]);) 2025.11.13 09:23:11.266200 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:11.324555 [ 16233 ] {acb2604d-24de-409d-80df-d321ddbcf43b} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 615, line 616) (in query: SELECT getMaxTableNameLengthForDatabase([NULL], [NULL], [NULL]);) 2025.11.13 09:23:11.339704 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMaxTableNameLengthForDatabase doesn't match: passed 3, should be 1: In scope SELECT getMaxTableNameLengthForDatabase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:11.359335 [ 6078 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 609.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:11.360282 [ 6078 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 609.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:11.419137 [ 6078 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 609.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:11.469100 [ 16233 ] {3c4f08dc-af8c-48e2-a6b5-ef02dd3a1ab9} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 616, line 617) (in query: SELECT getOSKernelVersion([NULL], [NULL], [NULL]);) 2025.11.13 09:23:11.481654 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:11.535879 [ 16233 ] {3921eb87-a752-4853-8f0e-c12c5bfff691} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 617, line 618) (in query: SELECT getServerPort([NULL], [NULL], [NULL]);) 2025.11.13 09:23:11.547916 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:11.625157 [ 16233 ] {3811534b-0e6a-4cb8-8ab5-b28d7fdbfc23} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 618, line 619) (in query: SELECT getSetting([NULL], [NULL], [NULL]);) 2025.11.13 09:23:11.638042 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:11.693496 [ 16233 ] {77bae967-a68c-4d3e-a257-3bc767cd9941} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 619, line 620) (in query: SELECT getSettingOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:23:11.710841 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSettingOrDefault doesn't match: passed 3, should be 2: In scope SELECT getSettingOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:11.770692 [ 16233 ] {ac231cd8-4de0-48c1-be1f-175f531fe3b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 620, line 621) (in query: SELECT getSizeOfEnumType([NULL], [NULL], [NULL]);) 2025.11.13 09:23:11.783263 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:11.839306 [ 16233 ] {d58f45e5-f367-480d-a5aa-464f93c74352} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 621, line 622) (in query: SELECT getSubcolumn([NULL], [NULL], [NULL]);) 2025.11.13 09:23:11.853188 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:11.961309 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_204_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 625.12 MiB (attempt to allocate chunk of 2.15 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c3f 12. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:47: DB::CompressedWriteBuffer::nextImpl() @ 0x000000003dd3a5a7 13. DB::WriteBuffer::next() @ 0x0000000008c37ea1 14. ./src/IO/HashingWriteBuffer.h:63: DB::HashingWriteBuffer::nextImpl() @ 0x000000003952910e 15. DB::WriteBuffer::next() @ 0x0000000008c37ea1 16. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:146: DB::SerializationString::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f7b6721 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:126: DB::ISerialization::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5896d4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:434: DB::MergeTreeDataPartWriterWide::writeSingleGranule(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::shared_ptr&, DB::ISerialization::SerializeBinaryBulkSettings&, DB::Granule const&) @ 0x0000000039be9bc7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:498: DB::MergeTreeDataPartWriterWide::writeColumn(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::vector> const&) @ 0x0000000039be6529 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:343: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039be1a84 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:11.963518 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_204_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 625.12 MiB (attempt to allocate chunk of 2.15 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c3f 12. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:47: DB::CompressedWriteBuffer::nextImpl() @ 0x000000003dd3a5a7 13. DB::WriteBuffer::next() @ 0x0000000008c37ea1 14. ./src/IO/HashingWriteBuffer.h:63: DB::HashingWriteBuffer::nextImpl() @ 0x000000003952910e 15. DB::WriteBuffer::next() @ 0x0000000008c37ea1 16. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:146: DB::SerializationString::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f7b6721 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:126: DB::ISerialization::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5896d4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:434: DB::MergeTreeDataPartWriterWide::writeSingleGranule(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::shared_ptr&, DB::ISerialization::SerializeBinaryBulkSettings&, DB::Granule const&) @ 0x0000000039be9bc7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:498: DB::MergeTreeDataPartWriterWide::writeColumn(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::vector> const&) @ 0x0000000039be6529 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:343: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039be1a84 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:12.160905 [ 16233 ] {03c56f0d-1ee7-472f-bbdd-c57239ab51c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 622, line 623) (in query: SELECT getTypeSerializationStreams([NULL], [NULL], [NULL]);) 2025.11.13 09:23:12.187329 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:12.239977 [ 16233 ] {008e2cd4-a132-4722-96fa-89f3f4cd327c} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 623, line 624) (in query: SELECT globalIn([NULL], [NULL], [NULL]);) 2025.11.13 09:23:12.272144 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:12.330549 [ 16233 ] {ba22e281-4c2e-4f1a-a0cd-5a2fbe7bb1bc} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 624, line 625) (in query: SELECT globalInIgnoreSet([NULL], [NULL], [NULL]);) 2025.11.13 09:23:12.345786 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:12.411441 [ 16233 ] {e52b0d94-6546-4317-a182-cfd75471005f} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 625, line 626) (in query: SELECT globalNotIn([NULL], [NULL], [NULL]);) 2025.11.13 09:23:12.452592 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:12.507706 [ 16233 ] {3cbf599c-2072-43eb-a3a2-f84045b52ab5} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 626, line 627) (in query: SELECT globalNotInIgnoreSet([NULL], [NULL], [NULL]);) 2025.11.13 09:23:12.518975 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:12.590143 [ 16233 ] {2cf367d0-6a58-4e35-86ce-2581c697b45d} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 627, line 628) (in query: SELECT globalNotNullIn([NULL], [NULL], [NULL]);) 2025.11.13 09:23:12.602129 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:12.687415 [ 16233 ] {79156c2c-8dc9-4375-8dbd-185f3e642c08} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 628, line 629) (in query: SELECT globalNotNullInIgnoreSet([NULL], [NULL], [NULL]);) 2025.11.13 09:23:12.700972 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:12.737262 [ 16344 ] {cb3c9700-7096-4d7e-8a8f-482397e34c6c} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 630.13 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41304) (comment: 02932_parallel_replicas_fuzzer.sql) (query 3, line 5) (in query: INSERT INTO join_inner_table__fuzz_146 SELECT CAST('833c9e22-c245-4eb5-8745-117a9a1f26b1', 'UUID') AS id, CAST(rowNumberInAllBlocks(), 'String') AS key, * FROM generateRandom('number Int64, value1 String, value2 String, time Int64', 1, 10, 2) LIMIT 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 2025.11.13 09:23:12.755540 [ 16233 ] {6d926ee3-270f-4ab9-b5cf-419abb052c7e} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 629, line 630) (in query: SELECT globalNullIn([NULL], [NULL], [NULL]);) 2025.11.13 09:23:12.767540 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:12.796316 [ 16344 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 630.13 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:23:12.825408 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_204_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 549.76 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:12.827527 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_204_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 549.76 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:12.877875 [ 16233 ] {5485b76a-204f-4e29-b074-5f19e1ea85e0} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 630, line 631) (in query: SELECT globalNullInIgnoreSet([NULL], [NULL], [NULL]);) 2025.11.13 09:23:12.902897 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:12.942840 [ 16215 ] {d906400e-1cc5-4746-babf-0fa77e59310a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1': while executing 'FUNCTION arraySplit(number Array(Array(Nothing)) -> toUInt8(number) :: 1, array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String))) :: 2) -> arraySplit(number Array(Array(Nothing)) -> toUInt8(number), array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String)))) Array(Array(Array(Array(Nothing)))) : 4'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60184) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (query 19, line 57) (in query: SELECT count(arraySplit(number -> toUInt8(number), [arraySplit(x -> toUInt8(number), [])])) FROM numbers(10) GROUP BY number, [number] WITH ROLLUP settings group_by_use_nulls=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c954489 5. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 12. ./src/Functions/FunctionsMiscellaneous.h:67: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000302b5be5 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 17. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x0000000037522ca0 18. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e75f8cb 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 2025.11.13 09:23:12.967261 [ 16215 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1': while executing 'FUNCTION arraySplit(number Array(Array(Nothing)) -> toUInt8(number) :: 1, array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String))) :: 2) -> arraySplit(number Array(Array(Nothing)) -> toUInt8(number), array(arraySplit(x Nothing -> toUInt8(__table1.number), _CAST([]_Array(Nothing), 'Array(Nothing)'_String)))) Array(Array(Array(Array(Nothing)))) : 4'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./src/Functions/FunctionsConversion.h:2543: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c954489 5. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt8, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c952e02 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 12. ./src/Functions/FunctionsMiscellaneous.h:67: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000302b5be5 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 16. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 17. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x0000000037522ca0 18. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001e75f8cb 19. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 23. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 24. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 25. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 26. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:23:12.975535 [ 16233 ] {65d12b53-e99d-41ad-9f53-34c85e8e357c} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 631, line 632) (in query: SELECT globalVariable([NULL], [NULL], [NULL]);) 2025.11.13 09:23:13.000788 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:13.146992 [ 16233 ] {8b2b2722-e58e-441f-aa82-77b818c81c48} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 632, line 633) (in query: SELECT greatCircleAngle([NULL], [NULL], [NULL]);) 2025.11.13 09:23:13.171838 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:13.296266 [ 16233 ] {e1c0aa9e-29c3-4a2f-8d14-cdbaa896546f} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 633, line 634) (in query: SELECT greatCircleDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:23:13.309227 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:13.442528 [ 16233 ] {d0f5332d-2d08-47cd-8f9c-fa89c45c51f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 634, line 635) (in query: SELECT greater([NULL], [NULL], [NULL]);) 2025.11.13 09:23:13.455690 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:13.512383 [ 16233 ] {784998ed-440c-48a3-8510-efa0d518955d} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 635, line 636) (in query: SELECT greaterOrEquals([NULL], [NULL], [NULL]);) 2025.11.13 09:23:13.524633 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:13.750219 [ 16233 ] {3fd25845-48bb-49b7-9846-d76b60de5a4c} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 637, line 638) (in query: SELECT groupArray([NULL], [NULL], [NULL]);) 2025.11.13 09:23:13.763084 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:13.817948 [ 16233 ] {1f2776e6-b52e-49ca-b725-d6a42a9d3649} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 638, line 639) (in query: SELECT groupArrayInsertAt([NULL], [NULL], [NULL]);) 2025.11.13 09:23:13.831948 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:13.979249 [ 16233 ] {5e35b3c2-b907-4bec-9646-7bb52b0c5430} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 639, line 640) (in query: SELECT groupArrayIntersect([NULL], [NULL], [NULL]);) 2025.11.13 09:23:13.990474 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.049273 [ 16233 ] {4ad568fc-a47a-48da-b7e7-80793c7bb114} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 640, line 641) (in query: SELECT groupArrayLast([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.073797 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.116781 [ 16233 ] {13f69db2-58bd-411d-a453-628af4b18bf0} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 641, line 642) (in query: SELECT groupArrayMovingAvg([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.120750 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_204_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 603.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column value7): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 10670): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:14.122770 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_204_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 603.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column value7): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_181_197_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 10670): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:14.132711 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.182059 [ 16233 ] {8a9c3b3a-c1ee-475c-b069-aaa8fc76dc65} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 642, line 643) (in query: SELECT groupArrayMovingSum([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.193016 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.244371 [ 16233 ] {762f46c1-f503-4de2-a9e6-18bca59866a4} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 643, line 644) (in query: SELECT groupArraySample([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.255144 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.306931 [ 16233 ] {86e2e535-74f8-4836-8fb7-32ab7177548c} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 644, line 645) (in query: SELECT groupArraySorted([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.317948 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.383944 [ 17383 ] {daa2f28f-591c-4297-834f-7a16d219445c} executeQuery: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41316) (comment: 02112_with_fill_interval.sql) (query 15, line 21) (in query: SELECT d, count() FROM with_fill_date GROUP BY d ORDER BY d WITH FILL STEP INTERVAL 1 HOUR LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000384b6fea 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:85: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000003c122b95 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c10dd9c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c10660e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c105a25 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1dce66 9. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f1dbfd9 10. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f234f41 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1044b4 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:23:14.447571 [ 17383 ] {} TCPHandler: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000384b6fea 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:85: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000003c122b95 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c10dd9c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c10660e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c105a25 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1dce66 9. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f1dbfd9 10. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f234f41 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1044b4 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:23:14.465648 [ 16233 ] {6b31b904-1206-495a-babb-77c2e420f2c8} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 645, line 646) (in query: SELECT groupBitAnd([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.478106 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.535883 [ 16186 ] {1060477a-9c42-4163-bf30-0e2eddf726b5} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 528.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41350) (comment: 03171_direct_dict_short_circuit_bug.sql) (query 6, line 16) (in query: INSERT INTO simple_key_simple_attributes_source_table VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/StorageLog.cpp:366: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x0000000038f6935c 14. ./contrib/llvm-project/libcxx/include/__utility/pair.h:478: std::unique_ptr, void*>, std::__tree_node_destructor, void*>>>> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__construct_node, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x0000000038f68c08 15. ./contrib/llvm-project/libcxx/include/__tree:1779: std::pair, std::__tree_node, void*>*, long>>, bool> std::map, std::allocator>>::try_emplace[abi:ne190107] const&, String const&, unsigned long, std::shared_ptr&, unsigned long const&>(String const&, std::shared_ptr const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&) @ 0x0000000038f67d83 16. ./build_docker/./src/Storages/StorageLog.cpp:500: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000038f5a1c3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/StorageLog.cpp:487: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x0000000038f3cb45 20. ./build_docker/./src/Storages/StorageLog.cpp:420: DB::LogSink::consume(DB::Chunk&) @ 0x0000000038f3c493 21. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 28. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 29. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 30. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:23:14.540638 [ 16233 ] {c1ea4035-75ea-4f55-9cae-451d612be563} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 646, line 647) (in query: SELECT groupBitOr([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.553146 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.555907 [ 16186 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 528.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/StorageLog.cpp:366: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x0000000038f6935c 14. ./contrib/llvm-project/libcxx/include/__utility/pair.h:478: std::unique_ptr, void*>, std::__tree_node_destructor, void*>>>> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__construct_node, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x0000000038f68c08 15. ./contrib/llvm-project/libcxx/include/__tree:1779: std::pair, std::__tree_node, void*>*, long>>, bool> std::map, std::allocator>>::try_emplace[abi:ne190107] const&, String const&, unsigned long, std::shared_ptr&, unsigned long const&>(String const&, std::shared_ptr const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&) @ 0x0000000038f67d83 16. ./build_docker/./src/Storages/StorageLog.cpp:500: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000038f5a1c3 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/StorageLog.cpp:487: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x0000000038f3cb45 20. ./build_docker/./src/Storages/StorageLog.cpp:420: DB::LogSink::consume(DB::Chunk&) @ 0x0000000038f3c493 21. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 28. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 29. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 30. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:23:14.569061 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_205_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 560.26 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:14.571021 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_205_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 560.26 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:14.673057 [ 16233 ] {8007aab8-7c1b-455c-b30c-8523cd0e42a5} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 647, line 648) (in query: SELECT groupBitXor([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.686108 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.747003 [ 16233 ] {5107835b-360a-495f-a496-1e57f4341a7a} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 648, line 649) (in query: SELECT groupBitmap([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.761488 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.837781 [ 16233 ] {b6e3da9e-e364-47cf-9413-904ad6477b51} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 649, line 650) (in query: SELECT groupBitmapAnd([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.856016 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.908767 [ 16233 ] {e32b3435-0d20-4eba-919f-b4d90820c8a3} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 650, line 651) (in query: SELECT groupBitmapOr([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.922069 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:14.978088 [ 16233 ] {cb650db4-6f72-41c3-a549-c2532b4edb88} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 651, line 652) (in query: SELECT groupBitmapXor([NULL], [NULL], [NULL]);) 2025.11.13 09:23:14.992172 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:15.126693 [ 16233 ] {88ecdd45-02a3-4026-8d75-5f4be7ad3d65} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 652, line 653) (in query: SELECT groupConcat([NULL], [NULL], [NULL]);) 2025.11.13 09:23:15.149134 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:15.203008 [ 16233 ] {4d9c249c-e4af-4b94-891a-d20fdc744527} executeQuery: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 653, line 654) (in query: SELECT groupUniqArray([NULL], [NULL], [NULL]);) 2025.11.13 09:23:15.229762 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:15.277416 [ 16233 ] {1b35851a-9847-423c-9779-495e98ba34b9} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 654, line 655) (in query: SELECT group_concat([NULL], [NULL], [NULL]);) 2025.11.13 09:23:15.292121 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:15.415443 [ 16233 ] {a0962a80-2b6a-4417-ac2b-8af56a70961c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 655, line 656) (in query: SELECT h3CellAreaM2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:15.431979 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:15.487058 [ 16233 ] {2aeaeb7a-213d-41fa-9eec-3e7f6e3c339a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 656, line 657) (in query: SELECT h3CellAreaRads2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:15.509550 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:15.591977 [ 16233 ] {d03d5191-8c27-425c-bef3-3cff87dc57c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 657, line 658) (in query: SELECT h3Distance([NULL], [NULL], [NULL]);) 2025.11.13 09:23:15.605611 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:15.735109 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_205_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 616.83 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9467): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:15.737437 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_205_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 616.83 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9467): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:15.754559 [ 16233 ] {06c7c1d7-f02e-412e-b5e3-d0c276667b23} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 658, line 659) (in query: SELECT h3EdgeAngle([NULL], [NULL], [NULL]);) 2025.11.13 09:23:15.767502 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:15.831532 [ 3731 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_122_9} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 616.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:15.833532 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_122_9}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 616.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:15.947572 [ 16233 ] {35bfeecf-6ee6-451e-ac15-123d66897863} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 659, line 660) (in query: SELECT h3EdgeLengthKm([NULL], [NULL], [NULL]);) 2025.11.13 09:23:15.958875 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:16.017871 [ 16233 ] {8448a12b-426b-427e-9d5e-8378a2cc7a2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 660, line 661) (in query: SELECT h3EdgeLengthM([NULL], [NULL], [NULL]);) 2025.11.13 09:23:16.030367 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:16.126588 [ 16233 ] {25545f9e-94fb-4f19-b841-5212751d47ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 661, line 662) (in query: SELECT h3ExactEdgeLengthKm([NULL], [NULL], [NULL]);) 2025.11.13 09:23:16.144155 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:16.197224 [ 16233 ] {041921f0-d29f-427c-9f3d-b6aff9977424} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 662, line 663) (in query: SELECT h3ExactEdgeLengthM([NULL], [NULL], [NULL]);) 2025.11.13 09:23:16.209850 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:16.213478 [ 17383 ] {51257d6c-b7d3-47ae-810a-0412243bbe5a} executeQuery: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41316) (comment: 02112_with_fill_interval.sql) (query 24, line 35) (in query: SELECT d, count() FROM with_fill_date GROUP BY d ORDER BY d WITH FILL STEP INTERVAL 1 HOUR LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000384b6fea 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:85: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000003c122b95 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c10dd9c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c10660e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c105a25 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1dce66 9. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f1dbfd9 10. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f234f41 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1044b4 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:23:16.221497 [ 17383 ] {} TCPHandler: Code: 475. DB::Exception: Value of step is to low (3600 seconds). Must be >= 1 day. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, long&&) @ 0x00000000384b6fea 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:85: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000003c122b95 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c10dd9c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c10660e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c105a25 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1dce66 9. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f1dbfd9 10. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f234f41 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1044b4 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:23:16.342581 [ 16233 ] {7e4d02af-d7b3-4bbd-b2c9-b3a9fadc9017} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 663, line 664) (in query: SELECT h3ExactEdgeLengthRads([NULL], [NULL], [NULL]);) 2025.11.13 09:23:16.351101 [ 16693 ] {0e6bd58f-e43b-428a-9707-11ba7451f6b1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53184) (comment: 00094_union_race_conditions_5.sh) (query 86, line 86) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:23:16.355511 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:16.368234 [ 16693 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:23:16.480047 [ 16233 ] {45ee8802-08df-4b93-b696-7b79c1abe5cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 664, line 665) (in query: SELECT h3GetBaseCell([NULL], [NULL], [NULL]);) 2025.11.13 09:23:16.493745 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:16.598095 [ 16233 ] {cf8d7778-a610-43c3-819d-6d004009fdb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 665, line 666) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]);) 2025.11.13 09:23:16.613641 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:16.666239 [ 16233 ] {8c5f851d-92a5-400c-93d9-879da038ed57} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 666, line 667) (in query: SELECT h3GetFaces([NULL], [NULL], [NULL]);) 2025.11.13 09:23:16.723102 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:16.811470 [ 16233 ] {90100e49-ca7a-48ab-b771-f271486ccafe} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 667, line 668) (in query: SELECT h3GetIndexesFromUnidirectionalEdge([NULL], [NULL], [NULL]);) 2025.11.13 09:23:16.888987 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.013758 [ 16233 ] {c7bb2563-cd49-40e4-9a6f-1c4d873968d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 668, line 669) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.025598 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.088666 [ 16233 ] {ccba00e7-99ba-4594-9c23-9fdc8dd3bf83} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 669, line 670) (in query: SELECT h3GetPentagonIndexes([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.099791 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.211034 [ 16233 ] {2c0af8bb-2a80-4e80-b3d6-ce21dd051fbc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 670, line 671) (in query: SELECT h3GetRes0Indexes([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.227448 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.273896 [ 16233 ] {267baba7-77b4-4182-94b7-a47d4508770b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 671, line 672) (in query: SELECT h3GetResolution([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.276887 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_205_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 600.81 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 2 with max_rows_to_read = 9251): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:17.278673 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_205_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 600.81 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 2 with max_rows_to_read = 9251): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:17.287409 [ 3724 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_122_9} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 589.53 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:17.289794 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_122_9}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 589.53 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:17.290587 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.349652 [ 16233 ] {7839d697-b07a-40b3-9090-fa42db554f8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 672, line 673) (in query: SELECT h3GetUnidirectionalEdge([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.364090 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.499716 [ 16233 ] {0bcc628f-a09a-471b-9d5b-666d9cf0e8d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 673, line 674) (in query: SELECT h3GetUnidirectionalEdgeBoundary([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.512512 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.648493 [ 16233 ] {f85652b2-a3c6-484c-a29a-64f20dfddc2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 674, line 675) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.660400 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.722158 [ 16233 ] {fe2a8351-cfac-4575-a45a-71e75f29f4d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 675, line 676) (in query: SELECT h3HexAreaKm2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.734821 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.806847 [ 16233 ] {335ea318-c275-4ba0-94fa-1e857a212942} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 676, line 677) (in query: SELECT h3HexAreaM2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.823605 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.883978 [ 16233 ] {d453e685-3a5a-4d3d-8d9e-f12b9ce0e02b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 677, line 678) (in query: SELECT h3HexRing([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.896899 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:17.954687 [ 16233 ] {5c4d1242-6e9d-4cfd-8d46-c191879ef170} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 678, line 679) (in query: SELECT h3IndexesAreNeighbors([NULL], [NULL], [NULL]);) 2025.11.13 09:23:17.967122 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:18.049360 [ 16233 ] {476356bd-0919-4bbc-87fa-e60ad2467bfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 679, line 680) (in query: SELECT h3IsPentagon([NULL], [NULL], [NULL]);) 2025.11.13 09:23:18.115954 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:18.180477 [ 16233 ] {0a2082f8-329d-460a-9648-69bfbebd66a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 680, line 681) (in query: SELECT h3IsResClassIII([NULL], [NULL], [NULL]);) 2025.11.13 09:23:18.197910 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:18.348184 [ 16233 ] {63947faa-a4bc-4804-bde9-3fe8cf1aeb56} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 681, line 682) (in query: SELECT h3IsValid([NULL], [NULL], [NULL]);) 2025.11.13 09:23:18.366213 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:18.485230 [ 18700 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 617.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:18.486288 [ 18700 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 617.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:18.552731 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_205_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 620.64 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9467): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:18.554491 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_205_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 620.64 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9467): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:18.598178 [ 16233 ] {4a5830c3-8ac2-4e75-9618-1aae7154f58f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 682, line 683) (in query: SELECT h3Line([NULL], [NULL], [NULL]);) 2025.11.13 09:23:18.613793 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:18.675912 [ 16233 ] {1127607c-9ac9-4c60-aa4f-be54ef98abd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 683, line 684) (in query: SELECT h3NumHexagons([NULL], [NULL], [NULL]);) 2025.11.13 09:23:18.771234 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:18.843362 [ 16233 ] {bc31bc2a-592f-4797-b632-0c5d8174f376} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 684, line 685) (in query: SELECT h3PointDistKm([NULL], [NULL], [NULL]);) 2025.11.13 09:23:18.868956 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:19.024526 [ 16233 ] {b284cd83-174f-424a-af9b-7ed356122331} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 685, line 686) (in query: SELECT h3PointDistM([NULL], [NULL], [NULL]);) 2025.11.13 09:23:19.048532 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:19.094349 [ 16233 ] {72701685-d310-4ca4-9fc3-1fe7fdf59e2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 686, line 687) (in query: SELECT h3PointDistRads([NULL], [NULL], [NULL]);) 2025.11.13 09:23:19.137219 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:19.289051 [ 16233 ] {a659d872-47f7-49b4-bf20-3a941d59a8f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 687, line 688) (in query: SELECT h3ToCenterChild([NULL], [NULL], [NULL]);) 2025.11.13 09:23:19.298501 [ 3724 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_206_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 615.47 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column value1): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 8481): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:19.300327 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_206_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 615.47 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column value1): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_159_180_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 8481): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:19.305089 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:19.361934 [ 16233 ] {e3fe5e35-59d1-4ede-a764-56a87be1a3a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 688, line 689) (in query: SELECT h3ToChildren([NULL], [NULL], [NULL]);) 2025.11.13 09:23:19.374593 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:19.431983 [ 16233 ] {fe78974c-6a5d-49d4-916c-1b8d916c4580} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 689, line 690) (in query: SELECT h3ToGeo([NULL], [NULL], [NULL]);) 2025.11.13 09:23:19.443017 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:19.492210 [ 18700 ] {4f73636b-80e3-4a7b-b2b0-52bb0181098b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41562) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_01516_test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:19.506033 [ 18700 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:19.600090 [ 16233 ] {0c7ddeab-b73c-4698-95ec-b3fdfa7bb2cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 690, line 691) (in query: SELECT h3ToGeoBoundary([NULL], [NULL], [NULL]);) 2025.11.13 09:23:19.611267 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:19.668336 [ 16233 ] {8ad3f61c-8d4f-4a20-ac1f-6e836fd14670} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 691, line 692) (in query: SELECT h3ToParent([NULL], [NULL], [NULL]);) 2025.11.13 09:23:19.679247 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:19.731584 [ 16233 ] {cf3d0cee-7a20-4e3b-ba4c-723c16d365bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 692, line 693) (in query: SELECT h3ToString([NULL], [NULL], [NULL]);) 2025.11.13 09:23:19.742925 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:19.798855 [ 16233 ] {cb989ac4-e418-4a1e-b7c9-87f0b0d90925} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 693, line 694) (in query: SELECT h3UnidirectionalEdgeIsValid([NULL], [NULL], [NULL]);) 2025.11.13 09:23:19.809813 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:19.932896 [ 16233 ] {6bb29675-90a1-490b-84d7-12bedb288762} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 694, line 695) (in query: SELECT h3kRing([NULL], [NULL], [NULL]);) 2025.11.13 09:23:19.944590 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:20.122484 [ 16233 ] {5a3268d4-9475-4128-932c-ac010a56c2a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 696, line 697) (in query: SELECT has([NULL], [NULL], [NULL]);) 2025.11.13 09:23:20.134616 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:20.216839 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_206_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 548.19 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:20.274865 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_159_206_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 548.19 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:20.284221 [ 16233 ] {f65b2428-a819-4c7f-b718-5caf169ae201} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 697, line 698) (in query: SELECT hasAll([NULL], [NULL], [NULL]);) 2025.11.13 09:23:20.297504 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:20.360434 [ 16233 ] {928a4f5d-d012-4ded-85c8-56af7dac974b} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 698, line 699) (in query: SELECT hasAny([NULL], [NULL], [NULL]);) 2025.11.13 09:23:20.371588 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:20.510831 [ 16233 ] {6fb7b439-837a-4b8d-9241-b5e18c525689} executeQuery: Code: 43. DB::Exception: First argument for function hasColumnInTable must be const String.: In scope SELECT hasColumnInTable([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 699, line 700) (in query: SELECT hasColumnInTable([NULL], [NULL], [NULL]);) 2025.11.13 09:23:20.525639 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function hasColumnInTable must be const String.: In scope SELECT hasColumnInTable([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:20.592755 [ 16233 ] {a4cb6edd-28fb-4ab1-8dbb-727c493629cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 700, line 701) (in query: SELECT hasSubsequence([NULL], [NULL], [NULL]);) 2025.11.13 09:23:20.606426 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:20.749272 [ 16233 ] {0762d6ed-1b81-48a0-9c29-b15a5fb9dcb8} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 701, line 702) (in query: SELECT hasSubsequenceCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:20.769470 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:20.840128 [ 16233 ] {aded7a00-8086-4ab4-82a0-5946b2d7d4ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 702, line 703) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:20.853856 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:20.923167 [ 16233 ] {3b0ab577-b0dd-4475-85ae-c9d695cf51b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 703, line 704) (in query: SELECT hasSubsequenceUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:20.937479 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:21.007528 [ 16233 ] {9b1aa3aa-ea8c-4bf2-bcf6-b25417285c10} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 704, line 705) (in query: SELECT hasSubstr([NULL], [NULL], [NULL]);) 2025.11.13 09:23:21.020396 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:21.070247 [ 16192 ] {9334e0b8-fa0d-4613-87d9-74e0378e4fb0} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 26, line 38) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.077734 [ 16233 ] {a3fde92c-eec3-458c-b8e4-894d25165693} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 705, line 706) (in query: SELECT hasThreadFuzzer([NULL], [NULL], [NULL]);) 2025.11.13 09:23:21.091089 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:21.107611 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.125924 [ 17683 ] {5c491ee7-759c-4a5a-af9c-2206cd631e8d} InterpreterCheckQuery: Check query for table test_vxn90tny.tp_1 (b9fe9f36-baa1-4652-8c82-82403128ddca) failed, path 0_5_5_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:21.143539 [ 16233 ] {86cd4ccc-278f-4813-ae61-a10accbdc478} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 706, line 707) (in query: SELECT hasToken([NULL], [NULL], [NULL]);) 2025.11.13 09:23:21.155685 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:21.183169 [ 17383 ] {12e7bf6f-1bd3-4e8b-9c13-e5ab6d1b9ce7} executeQuery: Code: 475. DB::Exception: STEP of Interval type can be used only with Date/DateTime types, but got UInt64. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41316) (comment: 02112_with_fill_interval.sql) (query 43, line 61) (in query: SELECT number FROM numbers(100) ORDER BY number WITH FILL STEP INTERVAL 1 HOUR;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:118: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000003c1229bd 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c10dd9c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c10660e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c105a25 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1dce66 9. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f1dbfd9 10. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f234f41 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1044b4 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.191667 [ 17383 ] {} TCPHandler: Code: 475. DB::Exception: STEP of Interval type can be used only with Date/DateTime types, but got UInt64. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:118: DB::getStepFunction(DB::Field const&, std::optional const&, std::shared_ptr const&) @ 0x000000003c1229bd 5. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:203: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003c10dd9c 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, 0>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003c10660e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:ne190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003c105a25 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f1dce66 9. ./build_docker/./src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f1dbfd9 10. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:135: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000002f234f41 11. ./build_docker/./src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1044b4 12. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.205167 [ 16192 ] {b3d6b297-835e-429a-8518-623d00663205} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 27, line 39) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key3 = tj.key3 AND t1.key2 = tj.key2 AND 1 > 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.213094 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.367445 [ 17383 ] {b0547495-1fe6-4bb5-8f00-77a6b3b48519} executeQuery: Code: 57. DB::Exception: Table test_5.with_fill_date already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02112_with_fill_interval.sql) (in query: /* ddl_entry=query-0000000157 */ CREATE TABLE test_5.with_fill_date UUID 'd7d3b83f-ea79-4ba2-a312-fc2eccbdee38' (`d` Date, `id` UInt32) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.376782 [ 16233 ] {0b40e155-f048-422c-95d2-cdc78759d12b} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 707, line 708) (in query: SELECT hasTokenCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:21.386303 [ 17383 ] {b0547495-1fe6-4bb5-8f00-77a6b3b48519} executeQuery: Code: 57. DB::Exception: Table test_5.with_fill_date already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41316) (comment: 02112_with_fill_interval.sql) (query 44, line 63) (in query: CREATE TABLE with_fill_date (d Date, id UInt32) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.388081 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:21.395726 [ 17383 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.with_fill_date already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.428755 [ 16192 ] {fe627ebe-8f16-4b35-a647-2c9a69675ed7} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 29, line 42) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.436375 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.452147 [ 16233 ] {068c6d90-7d04-42db-8cc2-4aedf0b9258e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 708, line 709) (in query: SELECT hasTokenCaseInsensitiveOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:21.463181 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:21.519770 [ 16233 ] {2002f0dd-123a-4afd-a2a7-ac8f26e24454} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 709, line 710) (in query: SELECT hasTokenOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:21.581100 [ 16192 ] {f23ff3fb-f508-40c7-87c5-ace6b9ec91ee} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 30, line 43) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.588286 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.609455 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:21.745959 [ 16192 ] {6a89204b-1129-4c5b-80eb-32c46d80de24} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 31, line 44) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON NULL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.753791 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:21.815659 [ 16233 ] {f192f21f-229f-4d14-8847-8738bd486671} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 710, line 711) (in query: SELECT hex([NULL], [NULL], [NULL]);) 2025.11.13 09:23:21.827607 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:22.019918 [ 16233 ] {1973003d-68fd-4042-8447-504aa08e1698} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 711, line 712) (in query: SELECT hilbertDecode([NULL], [NULL], [NULL]);) 2025.11.13 09:23:22.061579 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:22.066045 [ 16192 ] {fb90006f-c3db-40e4-b04d-04d74272afdb} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 32, line 45) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 != 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.073920 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.121909 [ 16233 ] {3b30a14d-b82d-44c1-8f33-2c0c3e80e1a3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 712, line 713) (in query: SELECT hilbertEncode([NULL], [NULL], [NULL]);) 2025.11.13 09:23:22.136227 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:22.237294 [ 16192 ] {ea11df57-2b1a-4ccd-bf4e-761282c5e51a} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 33, line 47) (in query: -- Here is another error code because equality is handled differently in CollectJoinOnKeysVisitor. -- We can change the error code, but it will become inconsistent for other cases -- where we actually expect AMBIGUOUS_COLUMN_NAME instead of INVALID_JOIN_ON_EXPRESSION/INCOMPATIBLE_TYPE_OF_JOIN. -- These checks are more reliable after switching to a new analyzer, they return INCOMPATIBLE_TYPE_OF_JOIN consistent with cases above SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.247715 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.277822 [ 16233 ] {f11bc278-2b5d-4424-a031-984bc87e02ac} executeQuery: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 713, line 714) (in query: SELECT histogram([NULL], [NULL], [NULL]);) 2025.11.13 09:23:22.290296 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:22.304821 [ 18392 ] {aceec57e-5788-41a6-9c2d-62fd3e2945c2} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42696) (comment: 01825_type_json_order_by.sql) (query 1, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.415689 [ 18392 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.446325 [ 16192 ] {fef80eae-a86d-4d42-93df-ed66d13c5f8b} executeQuery: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 34, line 52) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON 1 == 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.454619 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: JOIN with 'Join' table engine should be performed by storage keys [key3, key2, key1], but column '__rhs_const' was found. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>, String const&>(int, FormatStringHelperImpl, std::__wrap_iter, char>>::type, std::type_identity::type>, fmt::v11::join_view, std::__wrap_iter, char>&&, String const&) @ 0x0000000032cef6cd 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1245: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cec7a6 5. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 6. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.476466 [ 16233 ] {f91d0c41-be08-437a-8b0b-c3b8ff905b14} executeQuery: Code: 48. DB::Exception: Hive hash is not combineable for multiple arguments: In scope SELECT hiveHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 714, line 715) (in query: SELECT hiveHash([NULL], [NULL], [NULL]);) 2025.11.13 09:23:22.503818 [ 16192 ] {6ac87932-1595-48db-a986-70efda1cadf9} executeQuery: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr). (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 35, line 54) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000304cd95f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5279: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304c447a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5381: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7826 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.505838 [ 16233 ] {} TCPHandler: Code: 48. DB::Exception: Hive hash is not combineable for multiple arguments: In scope SELECT hiveHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.11.13 09:23:22.511382 [ 16192 ] {} TCPHandler: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, attr). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000304cd95f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5279: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304c447a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5381: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7826 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.554936 [ 16233 ] {92e035d4-bde2-4c0e-b3bd-332eacca2f55} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hop. Should be a date with time: In scope SELECT hop([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 715, line 716) (in query: SELECT hop([NULL], [NULL], [NULL]);) 2025.11.13 09:23:22.569110 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hop. Should be a date with time: In scope SELECT hop([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:22.628258 [ 16233 ] {8e0b982e-e779-41b2-8a3b-592d91e3e4d9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hopEnd. Should be a date with time: In scope SELECT hopEnd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 716, line 717) (in query: SELECT hopEnd([NULL], [NULL], [NULL]);) 2025.11.13 09:23:22.640436 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hopEnd. Should be a date with time: In scope SELECT hopEnd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:22.745003 [ 16192 ] {82e09105-865e-4a40-b2ab-16aec4110a1e} executeQuery: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, key3, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr). (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 36, line 55) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000304cd95f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5279: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304c447a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5381: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7826 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.752688 [ 16192 ] {} TCPHandler: Code: 47. DB::Exception: JOIN ALL INNER JOIN ... USING (key1, key2, key3, attr) using identifier 'attr' cannot be resolved from left table expression. In scope SELECT * FROM t1 ALL INNER JOIN tj USING (key1, key2, key3, attr). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&, String&&) @ 0x00000000304cd95f 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5279: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304c447a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5381: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7826 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:23:22.883220 [ 16233 ] {083d7e2c-0e6d-4235-ac34-72ca33b50688} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hopStart. Should be a date with time: In scope SELECT hopStart([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 717, line 718) (in query: SELECT hopStart([NULL], [NULL], [NULL]);) 2025.11.13 09:23:22.896072 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hopStart. Should be a date with time: In scope SELECT hopStart([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:22.957353 [ 16233 ] {fb94b6b5-90d2-4a42-a9e2-17069b16397a} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 718, line 719) (in query: SELECT hostName([NULL], [NULL], [NULL]);) 2025.11.13 09:23:22.968582 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:23.024455 [ 16233 ] {4565020e-12bc-4e36-9e33-32f00a8815f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 719, line 720) (in query: SELECT hostname([NULL], [NULL], [NULL]);) 2025.11.13 09:23:23.037476 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:23.174050 [ 16233 ] {9fb937fd-987c-480d-a657-f8ade288973d} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 720, line 721) (in query: SELECT hypot([NULL], [NULL], [NULL]);) 2025.11.13 09:23:23.189309 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:23.276788 [ 16233 ] {b2913b94-11ec-4577-a33f-33969e8987b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 3, should be 2: In scope SELECT icebergTruncate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 721, line 722) (in query: SELECT icebergTruncate([NULL], [NULL], [NULL]);) 2025.11.13 09:23:23.288991 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function icebergTruncate doesn't match: passed 3, should be 2: In scope SELECT icebergTruncate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:23.388632 [ 16233 ] {fbbb11bc-bee2-429f-97fe-91d1e7422d4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 722, line 723) (in query: SELECT identity([NULL], [NULL], [NULL]);) 2025.11.13 09:23:23.399923 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:23.536717 [ 16233 ] {e80b1792-14e4-493c-9aa7-46cdc8bf4dff} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 723, line 724) (in query: SELECT idnaDecode([NULL], [NULL], [NULL]);) 2025.11.13 09:23:23.552951 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:23.635001 [ 16233 ] {098753ff-f205-48c2-9337-f3b1527b789f} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 724, line 725) (in query: SELECT idnaEncode([NULL], [NULL], [NULL]);) 2025.11.13 09:23:23.680582 [ 16192 ] {afd83818-a1bd-4c97-96be-b893260a0d93} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 37, line 57) (in query: SELECT * FROM t1 ALL INNER JOIN tj USING (key2, key3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f5f01cd 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e34f8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:23.694849 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (2) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f5f01cd 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e34f8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:23.722246 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:23.836899 [ 16192 ] {3b109307-8d18-4138-bfcc-545ba3c9178f} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 38, line 58) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f5f01cd 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e34f8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:23.846128 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f5f01cd 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e34f8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:23.871794 [ 16233 ] {483d7852-2bbc-4fbf-b272-f702b03885a9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument (condition) of function if. Must be UInt8.: In scope SELECT if([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 725, line 726) (in query: SELECT if([NULL], [NULL], [NULL]);) 2025.11.13 09:23:23.884955 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument (condition) of function if. Must be UInt8.: In scope SELECT if([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:23.999195 [ 16233 ] {0e91e57a-04c4-4732-aa1f-7c08f0bb32a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 726, line 727) (in query: SELECT ifNotFinite([NULL], [NULL], [NULL]);) 2025.11.13 09:23:24.013373 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:24.058532 [ 16192 ] {a9da1327-35bc-4146-8377-021220b553e0} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 39, line 59) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f5f01cd 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e34f8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:24.069056 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (1) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f5f01cd 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e34f8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:24.078227 [ 16233 ] {239ebb57-66a3-4620-832a-f6ae2c7bce86} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 727, line 728) (in query: SELECT ifNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:24.092108 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:24.552423 [ 16233 ] {6b31cf1c-02dc-4cd3-954d-f1ac5e2f7160} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 729, line 730) (in query: SELECT ilike([NULL], [NULL], [NULL]);) 2025.11.13 09:23:24.568548 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:24.752986 [ 16233 ] {78a8e19b-838a-48e0-b80e-26858eb3600b} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 730, line 731) (in query: SELECT in([NULL], [NULL], [NULL]);) 2025.11.13 09:23:24.834422 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:24.889327 [ 16233 ] {7e36a2cc-55b8-45aa-bfe4-0c091a9cb638} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 731, line 732) (in query: SELECT inIgnoreSet([NULL], [NULL], [NULL]);) 2025.11.13 09:23:24.901610 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:25.050492 [ 16192 ] {878851eb-54e9-415e-9a49-aa6a35a7ce39} executeQuery: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 40, line 60) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.attr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000385ebdb7 4. ./build_docker/./src/Storages/StorageJoin.cpp:288: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e30ee 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:25.058601 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: Key 'key3' not found in JOIN ON section. Join engine keys 'key3, key2, key1' have to be used. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity, std::__wrap_iter, char>>::type>, String const&, char const*&&, fmt::v11::join_view, std::__wrap_iter, char>&&) @ 0x00000000385ebdb7 4. ./build_docker/./src/Storages/StorageJoin.cpp:288: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e30ee 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:25.159291 [ 16233 ] {c84a6661-7f3d-428f-99e7-cc69b71ea9ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 733, line 734) (in query: SELECT indexOf([NULL], [NULL], [NULL]);) 2025.11.13 09:23:25.171014 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:25.181058 [ 16192 ] {636fcb53-0c35-4f72-91da-749071c216ac} executeQuery: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41390) (comment: 02498_storage_join_key_positions.sql) (query 41, line 61) (in query: SELECT * FROM t1 ALL INNER JOIN tj ON t1.key1 = tj.key1 AND t1.key2 = tj.key2 AND t1.key3 = tj.key3 AND t1.key1 = tj.key1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f5f01cd 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e34f8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:25.190365 [ 16192 ] {} TCPHandler: Code: 264. DB::Exception: Number of keys in JOIN ON section (4) doesn't match number of keys in Join engine (3). (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&&) @ 0x000000001f5f01cd 4. ./build_docker/./src/Storages/StorageJoin.cpp:264: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e34f8 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:25.226599 [ 16233 ] {e7fab647-a659-4031-9683-889237b13709} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 734, line 735) (in query: SELECT indexOfAssumeSorted([NULL], [NULL], [NULL]);) 2025.11.13 09:23:25.238547 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOfAssumeSorted doesn't match: passed 3, should be 2: In scope SELECT indexOfAssumeSorted([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:25.326542 [ 16233 ] {e93adf40-006e-4c96-afc3-eb061d7fa9f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 735, line 736) (in query: SELECT initcap([NULL], [NULL], [NULL]);) 2025.11.13 09:23:25.337957 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:25.393606 [ 16233 ] {36e0d50c-9a52-457a-ac7b-acede49f516d} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 736, line 737) (in query: SELECT initcapUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:25.404984 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:25.461859 [ 16233 ] {59c4598b-6584-4279-b5e2-47ec1ff63083} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 737, line 738) (in query: SELECT initialQueryID([NULL], [NULL], [NULL]);) 2025.11.13 09:23:25.474247 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:25.525484 [ 16233 ] {3be4ef47-99b3-4d25-b726-3f172380d3fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initialQueryStartTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 738, line 739) (in query: SELECT initialQueryStartTime([NULL], [NULL], [NULL]);) 2025.11.13 09:23:25.540287 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initialQueryStartTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:25.699986 [ 16233 ] {041c10fe-671b-4904-9ca8-987d5200d9e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 739, line 740) (in query: SELECT initial_query_id([NULL], [NULL], [NULL]);) 2025.11.13 09:23:25.740159 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:26.026105 [ 16186 ] {9f41bed5-7f00-43f7-822f-1e5c0cadc0f4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:41468) (comment: 00094_union_race_conditions_5.sh) (query 40, line 40) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:23:26.027980 [ 16233 ] {eb96da44-463d-4a07-a5c2-b70f3230ce4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initial_query_start_time([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 740, line 741) (in query: SELECT initial_query_start_time([NULL], [NULL], [NULL]);) 2025.11.13 09:23:26.043511 [ 16186 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:23:26.059748 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryStartTime doesn't match: passed 3, should be 0: In scope SELECT initial_query_start_time([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:26.119163 [ 16233 ] {777c31b7-494c-4ee6-8bfc-ad61d1cb1077} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 741, line 742) (in query: SELECT initializeAggregation([NULL], [NULL], [NULL]);) 2025.11.13 09:23:26.132267 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:26.199007 [ 16233 ] {024c1336-4ad1-4616-a852-47568878b055} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitive: In scope SELECT instr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 742, line 743) (in query: SELECT instr([NULL], [NULL], [NULL]);) 2025.11.13 09:23:26.226634 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitive: In scope SELECT instr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:26.237460 [ 17227 ] {5e9f6c4b-6aee-47f0-9988-81e2d0f451b9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42838) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_01516_test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:26.252867 [ 17227 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:26.352108 [ 16233 ] {4a0b9424-be34-4412-a35e-ec5926921669} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 743, line 744) (in query: SELECT intDiv([NULL], [NULL], [NULL]);) 2025.11.13 09:23:26.364974 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:26.412013 [ 10726 ] {552429ef-6474-4a53-9692-da622bb8fd07} InterpreterCheckQuery: Check query for table test_vxn90tny.tp_1 (584137d6-b8ff-4f04-9d18-e0926d7852e2) failed, path 0_1_1_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:26.433227 [ 16233 ] {de3d553f-2558-473a-9985-5eae81e1e286} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 744, line 745) (in query: SELECT intDivOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:23:26.446990 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:26.536086 [ 16233 ] {da935816-b36d-473b-ab34-6a436d480ddc} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 745, line 746) (in query: SELECT intExp10([NULL], [NULL], [NULL]);) 2025.11.13 09:23:26.583515 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:26.654378 [ 16233 ] {9e4d3e00-3574-4fbd-806b-46508b422ac8} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 746, line 747) (in query: SELECT intExp2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:26.674631 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:26.878780 [ 16233 ] {a00c31f9-7e49-4db5-87d3-5e503bcd32db} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 747, line 748) (in query: SELECT intHash32([NULL], [NULL], [NULL]);) 2025.11.13 09:23:26.892988 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:26.952560 [ 16233 ] {29ecf6a7-004d-485d-9233-4822261baa76} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 748, line 749) (in query: SELECT intHash64([NULL], [NULL], [NULL]);) 2025.11.13 09:23:27.109962 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:27.161582 [ 16233 ] {2208ad12-5fc5-4690-9cd8-15b1c24a9590} executeQuery: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 749, line 750) (in query: SELECT intervalLengthSum([NULL], [NULL], [NULL]);) 2025.11.13 09:23:27.176780 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:27.225380 [ 16231 ] {62fa78df-68d5-4bf6-902c-d6d5d1f60532} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42894) (comment: 03623_header_filtering.sql) (query 1, line 1) (in query: SELECT * FROM url('http://google.com', 'RawBLOB', 'data String', headers('exact_header' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:23:27.237966 [ 16231 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:23:27.260754 [ 16233 ] {eefee9a6-b1d8-4fac-8341-eb77daa04363} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 750, line 751) (in query: SELECT isConstant([NULL], [NULL], [NULL]);) 2025.11.13 09:23:27.275015 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:27.295050 [ 16231 ] {1d1f1bd1-aada-4751-8313-547111cd8bdd} executeQuery: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42894) (comment: 03623_header_filtering.sql) (query 2, line 8) (in query: SELECT * FROM url('http://google.com', 'RawBLOB', 'data String', headers('exact_header\t' = '[HIDDEN]', 'exact_header\t' = '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:23:27.304501 [ 16231 ] {} TCPHandler: Code: 36. DB::Exception: HTTP header "exact_header" is forbidden in configuration file, see . (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Common/HTTPHeaderFilter.cpp:34: DB::HTTPHeaderFilter::checkAndNormalizeHeaders(std::vector>&) const @ 0x0000000027118741 5. ./build_docker/./src/Storages/StorageURL.cpp:1440: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038e71f00 6. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::__shared_ptr_emplace>::__shared_ptr_emplace[abi:ne190107]&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, std::allocator, 0>(std::allocator, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x0000000026771c01 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:843: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, DB::StorageID, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription, String, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t, bool const&, 0>(std::allocator const&, String const&, DB::StorageID&&, String const&, std::nullopt_t const&, DB::ColumnsDescription const&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, String const&, std::vector> const&, String const&, std::nullptr_t&&, bool const&) @ 0x00000000267718bb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002676e307 9. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 11. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:23:27.416472 [ 16233 ] {cfa050e6-e20d-4e87-92b4-c1936060cf2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 3, should be 1 or 2.: In scope SELECT isDecimalOverflow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 751, line 752) (in query: SELECT isDecimalOverflow([NULL], [NULL], [NULL]);) 2025.11.13 09:23:27.431853 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 3, should be 1 or 2.: In scope SELECT isDecimalOverflow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:27.562499 [ 18773 ] {ccc26f2f-7ffb-4e08-814f-ffbafc2d69d9} InterpreterCheckQuery: Check query for table test_vxn90tny.tp_1 (584137d6-b8ff-4f04-9d18-e0926d7852e2) failed, path 0_1_1_0, reason: Code: 227. DB::Exception: Found unexpected projection directories: pp.proj. (UNEXPECTED_FILE_IN_DATA_PART) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:27.670452 [ 16233 ] {f178ece0-6478-4d3a-b305-b621f5d4bc90} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 752, line 753) (in query: SELECT isDynamicElementInSharedData([NULL], [NULL], [NULL]);) 2025.11.13 09:23:27.685452 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:27.838481 [ 16233 ] {10cbcf86-410b-45cd-9c4d-3a537350c691} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 753, line 754) (in query: SELECT isFinite([NULL], [NULL], [NULL]);) 2025.11.13 09:23:27.853705 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:27.983897 [ 16233 ] {0233a84a-e8b2-4c36-aa8e-d3a129cc7053} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 754, line 755) (in query: SELECT isIPAddressInRange([NULL], [NULL], [NULL]);) 2025.11.13 09:23:27.996873 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:28.126149 [ 16233 ] {938ffa58-db85-4dc4-9372-de7908c33522} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 755, line 756) (in query: SELECT isIPv4String([NULL], [NULL], [NULL]);) 2025.11.13 09:23:28.139175 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:28.207791 [ 16233 ] {a54d7c09-fd80-4b4b-b7aa-3995959e7451} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 756, line 757) (in query: SELECT isIPv6String([NULL], [NULL], [NULL]);) 2025.11.13 09:23:28.225698 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:28.284193 [ 16233 ] {e69d4927-6c1b-42f4-8677-ecdc60d94c0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 757, line 758) (in query: SELECT isInfinite([NULL], [NULL], [NULL]);) 2025.11.13 09:23:28.300104 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:28.425184 [ 16233 ] {1340b7b9-203a-4883-a024-e8a075b67e3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 758, line 759) (in query: SELECT isNaN([NULL], [NULL], [NULL]);) 2025.11.13 09:23:28.440819 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:28.510371 [ 16233 ] {cee7b4e8-5ace-4faf-8652-27b32d98be10} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 759, line 760) (in query: SELECT isNotDistinctFrom([NULL], [NULL], [NULL]);) 2025.11.13 09:23:28.591987 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:28.660466 [ 16233 ] {6b089445-be9a-4a0b-8c80-33028caef2ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 760, line 761) (in query: SELECT isNotNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:28.672864 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:28.672885 [ 17249 ] {} test_vxn90tny.tp_1 (584137d6-b8ff-4f04-9d18-e0926d7852e2): Cannot quickly remove directory /var/lib/clickhouse/store/584/584137d6-b8ff-4f04-9d18-e0926d7852e2/delete_tmp_0_1_1_0/pp.proj by removing files; fallback to recursive removal. Reason: Code: 458. DB::ErrnoException: Cannot unlink file /var/lib/clickhouse/store/584/584137d6-b8ff-4f04-9d18-e0926d7852e2/delete_tmp_0_1_1_0/pp.proj/x.cmrk2: , errno: 2, strerror: No such file or directory. (CANNOT_UNLINK) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:28.731751 [ 16233 ] {9d4d7f3b-97bc-4271-aec5-acbb024c902e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 761, line 762) (in query: SELECT isNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:28.745336 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:28.889292 [ 16233 ] {c5cf6b06-78e6-42ee-a2ab-9c9c4df47987} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 762, line 763) (in query: SELECT isNullable([NULL], [NULL], [NULL]);) 2025.11.13 09:23:28.907999 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:28.976558 [ 16233 ] {9c2ea3ff-2763-48ea-8643-bba1bf8743ae} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 763, line 764) (in query: SELECT isValidJSON([NULL], [NULL], [NULL]);) 2025.11.13 09:23:28.990820 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:29.048485 [ 16233 ] {ab2c38f9-e703-4e2b-95ce-6eaa027bdcc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 764, line 765) (in query: SELECT isValidUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:29.059443 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:29.117954 [ 16233 ] {7be4e963-4e19-4045-aec5-9a2ed97e16e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 765, line 766) (in query: SELECT isZeroOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:29.129827 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:29.188958 [ 16233 ] {9c3f37f1-a784-42c1-93ab-149b6ff18200} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 766, line 767) (in query: SELECT jaroSimilarity([NULL], [NULL], [NULL]);) 2025.11.13 09:23:29.222085 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:29.324283 [ 16233 ] {b726eb38-3af6-4c7e-8b5c-5a1d78d515c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 767, line 768) (in query: SELECT jaroWinklerSimilarity([NULL], [NULL], [NULL]);) 2025.11.13 09:23:29.337789 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:29.410428 [ 16233 ] {c048e06b-5726-412d-9fd8-818a988862e6} executeQuery: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 768, line 769) (in query: SELECT javaHash([NULL], [NULL], [NULL]);) 2025.11.13 09:23:29.425969 [ 16233 ] {} TCPHandler: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.11.13 09:23:29.480705 [ 16233 ] {3353aea3-dc78-4bc3-9b74-9d259f88b8a9} executeQuery: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHashUTF16LE([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 769, line 770) (in query: SELECT javaHashUTF16LE([NULL], [NULL], [NULL]);) 2025.11.13 09:23:29.496302 [ 16233 ] {} TCPHandler: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHashUTF16LE([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.11.13 09:23:29.554703 [ 16233 ] {666bd3f1-0f6e-4fc1-b0ef-44dffa931d81} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 770, line 771) (in query: SELECT joinGet([NULL], [NULL], [NULL]);) 2025.11.13 09:23:29.566546 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:29.625160 [ 16233 ] {08920689-3a8e-47fe-8209-d98fe3335a18} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 771, line 772) (in query: SELECT joinGetOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:29.636214 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:29.758046 [ 16233 ] {418086b9-cbaf-4ba0-9b61-a1512b4cb67c} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 772, line 773) (in query: SELECT jsonMergePatch([NULL], [NULL], [NULL]);) 2025.11.13 09:23:29.798773 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:29.885879 [ 4170 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:29.887059 [ 4170 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:23:29.904184 [ 16233 ] {3fc97477-8a66-49c9-8794-dab49ae50cd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 773, line 774) (in query: SELECT jumpConsistentHash([NULL], [NULL], [NULL]);) 2025.11.13 09:23:29.918320 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:30.233184 [ 16355 ] {2afc91e2-673b-4c0f-83cf-5db7c6f50101} executeQuery: Code: 60. DB::Exception: Table test_13.replica_01108_1 does not exist. Maybe you meant test_13.replica_01108_1_tmp?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42990) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM RESTART REPLICA replica_01108_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:920: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x00000000339191f2 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:984: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x0000000033913629 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:761: DB::InterpreterSystemQuery::execute() @ 0x00000000338e038e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:30.313981 [ 16233 ] {1890e85a-0083-4e15-b9d7-24a2729d17fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 3, should be 1: In scope SELECT keccak256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 775, line 776) (in query: SELECT keccak256([NULL], [NULL], [NULL]);) 2025.11.13 09:23:30.327018 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function keccak256 doesn't match: passed 3, should be 1: In scope SELECT keccak256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:30.349237 [ 16355 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.replica_01108_1 does not exist. Maybe you meant test_13.replica_01108_1_tmp?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:920: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x00000000339191f2 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:984: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x0000000033913629 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:761: DB::InterpreterSystemQuery::execute() @ 0x00000000338e038e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:30.390117 [ 16233 ] {8ec43d47-4356-4baf-975e-a9c8b0213c4e} executeQuery: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 776, line 777) (in query: SELECT kolmogorovSmirnovTest([NULL], [NULL], [NULL]);) 2025.11.13 09:23:30.404252 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:30.470726 [ 16233 ] {262d3a40-a712-4d9e-a597-ad69bf2c625d} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 777, line 778) (in query: SELECT kostikConsistentHash([NULL], [NULL], [NULL]);) 2025.11.13 09:23:30.486254 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:31.123017 [ 17390 ] {af354c86-16a4-4bcc-a3f8-10c9b30fe98a} executeQuery: Code: 57. DB::Exception: Table test_13.replica_01108_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43034) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: RENAME TABLE replica_01108_1_tmp TO replica_01108_2, replica_01108_2_tmp TO replica_01108_3, replica_01108_3_tmp TO replica_01108_4, replica_01108_4_tmp TO replica_01108_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002ea4fcea 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:791: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031aef5ef 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032afdc4f 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:23:31.139650 [ 17390 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.replica_01108_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002ea4fcea 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:791: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031aef5ef 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032afdc4f 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:23:31.270181 [ 16233 ] {5908ef0b-4f81-464f-ad27-cd9082074e08} executeQuery: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 780, line 781) (in query: SELECT kurtPop([NULL], [NULL], [NULL]);) 2025.11.13 09:23:31.290137 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:31.350993 [ 16233 ] {285f0e9e-9259-4a7e-9c09-f59f162d90d9} executeQuery: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 781, line 782) (in query: SELECT kurtSamp([NULL], [NULL], [NULL]);) 2025.11.13 09:23:31.432849 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:31.570463 [ 16233 ] {8bf36a67-423f-4333-9a98-d3358373e845} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 782, line 783) (in query: SELECT lagInFrame([NULL], [NULL], [NULL]);) 2025.11.13 09:23:31.595859 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) 2025.11.13 09:23:31.641520 [ 5639 ] {c5c6bdcb-a558-426e-ba60-a9707570f667} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash64Keyed((0, 0), '1'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34610) (comment: 02534_keyed_siphash.sql) (query 193, line 266) (in query: select sipHash64Keyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e376b 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926808b 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009267992 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:23:31.655045 [ 5639 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash64Keyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e376b 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926808b 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009267992 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:23:31.717215 [ 16233 ] {9dc868a8-a147-4177-830c-10f745f8f1e1} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 783, line 784) (in query: SELECT largestTriangleThreeBuckets([NULL], [NULL], [NULL]);) 2025.11.13 09:23:31.733470 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:31.787275 [ 16233 ] {c55b19f0-59a2-43f6-9844-a31c257ace68} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 784, line 785) (in query: SELECT lastValueRespectNulls([NULL], [NULL], [NULL]);) 2025.11.13 09:23:31.813747 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:31.951528 [ 16233 ] {495d8855-6bb1-4080-b0ee-a19a2e599d07} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 785, line 786) (in query: SELECT last_value([NULL], [NULL], [NULL]);) 2025.11.13 09:23:31.972710 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:32.146203 [ 16233 ] {a5f1a96d-dca9-46a4-90ea-dede027c1de4} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 786, line 787) (in query: SELECT last_value_respect_nulls([NULL], [NULL], [NULL]);) 2025.11.13 09:23:32.159882 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:32.204911 [ 18391 ] {de0943ac-879f-48a8-bc76-dbfa023a4474} executeQuery: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort(toFixedString('01/12/2017,', 11)). (CANNOT_PARSE_DATETIME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60904) (comment: 03014_msan_parse_date_time.sql) (query 1, line 1) (in query: SELECT parseDateTimeBestEffort(toFixedString('01/12/2017,', 11));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa051f0 5. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d2a56 6. ./src/Functions/FunctionsConversion.h:2682: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abee4 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:23:32.213550 [ 18391 ] {} TCPHandler: Code: 41. DB::Exception: Cannot read DateTime: unexpected word after Date: In scope SELECT parseDateTimeBestEffort(toFixedString('01/12/2017,', 11)). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/parseDateTimeBestEffort.cpp:99: DB::parseDateTimeBestEffort(long&, DB::ReadBuffer&, DateLUTImpl const&, DateLUTImpl const&) @ 0x000000001fa051f0 5. ./src/Functions/FunctionsConversion.h:985: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x000000002d0d2a56 6. ./src/Functions/FunctionsConversion.h:2682: DB::detail::FunctionConvertFromString::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002d0abee4 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:23:32.223178 [ 16233 ] {c43ae74a-19ae-44d0-bb22-3e284f1f34e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 787, line 788) (in query: SELECT lcase([NULL], [NULL], [NULL]);) 2025.11.13 09:23:32.236876 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:32.295589 [ 16233 ] {341009de-6db6-4ea5-9cd0-9d2f67b21d19} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 788, line 789) (in query: SELECT lcm([NULL], [NULL], [NULL]);) 2025.11.13 09:23:32.307216 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:32.420323 [ 16233 ] {b88fa028-0aec-43ee-89fc-137fa0d0ffa5} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 789, line 790) (in query: SELECT leadInFrame([NULL], [NULL], [NULL]);) 2025.11.13 09:23:32.609698 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) 2025.11.13 09:23:32.798716 [ 16233 ] {5b3b0dd6-766c-44c1-831f-5ca019c6f784} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 791, line 792) (in query: SELECT left([NULL], [NULL], [NULL]);) 2025.11.13 09:23:32.802853 [ 18403 ] {e261bcbe-cdda-4f31-9f8b-002abd5797f4} executeQuery: Code: 60. DB::Exception: Table test_13.replica_01108_2 does not exist. Maybe you meant test_13.replica_01108_2_tmp?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60922) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM RESTART REPLICA replica_01108_2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:920: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x00000000339191f2 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:984: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x0000000033913629 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:761: DB::InterpreterSystemQuery::execute() @ 0x00000000338e038e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:32.810095 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:32.813941 [ 18403 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.replica_01108_2 does not exist. Maybe you meant test_13.replica_01108_2_tmp?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:920: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x00000000339191f2 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:984: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x0000000033913629 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:761: DB::InterpreterSystemQuery::execute() @ 0x00000000338e038e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:32.866351 [ 16233 ] {ef4c3efa-0a5e-4c23-933b-4cae46e52f70} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPad, should be string: In scope SELECT leftPad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 792, line 793) (in query: SELECT leftPad([NULL], [NULL], [NULL]);) 2025.11.13 09:23:32.886077 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPad, should be string: In scope SELECT leftPad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:32.928167 [ 5639 ] {bbafd6d0-a7b8-462d-8e36-04e6bcc4f9a7} executeQuery: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128Keyed((0, 0), '1'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34610) (comment: 02534_keyed_siphash.sql) (query 194, line 267) (in query: select sipHash128Keyed((0, 0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e376b 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093bb88a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093bb012 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:23:32.939142 [ 5639 ] {} TCPHandler: Code: 36. DB::Exception: The 1st element of the key tuple is not of type UInt64: In scope SELECT sipHash128Keyed((0, 0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e376b 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093bb88a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093bb012 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:23:32.957056 [ 16233 ] {b6ded16d-bbe4-4611-b628-4b7902939a34} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPadUTF8, should be string: In scope SELECT leftPadUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 793, line 794) (in query: SELECT leftPadUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:32.977825 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPadUTF8, should be string: In scope SELECT leftPadUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:33.022685 [ 10170 ] {27da4caa-1047-4033-87de-efb47759b973} executeQuery: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:42998) (comment: 00732_quorum_insert_lost_part_zookeeper_long.sql) (query 10, line 20) (in query: INSERT INTO quorum2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000003a3d2b9b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x000000003a41a872 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003a41a19f 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a3cc482 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a3a0437 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a3c94f4 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0ec2f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d7fc 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:23:33.037816 [ 16233 ] {644362e0-e653-4b50-a6dc-8dbb7ce3cec9} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 794, line 795) (in query: SELECT leftUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:33.039190 [ 10170 ] {} TCPHandler: Code: 319. DB::Exception: Unknown quorum status. The data was inserted in the local replica but we could not verify quorum. Reason: Timeout while waiting for quorum. (UNKNOWN_STATUS_OF_INSERT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1270: DB::ReplicatedMergeTreeSinkImpl::waitForQuorum(std::shared_ptr const&, String const&, String const&, int, int, unsigned long) const @ 0x000000003a3d2b9b 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1200: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()::operator()() const @ 0x000000003a41a872 6. ./src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda5'()&&)::'lambda'()&&) @ 0x000000003a41a19f 7. ./src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x000000003a3cc482 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x000000003a3a0437 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x000000003a3c94f4 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0ec2f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d7fc 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 17. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 18. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:23:33.108623 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:33.315166 [ 16233 ] {b819b5c9-5c73-411e-8e57-8b5807025387} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 795, line 796) (in query: SELECT lemmatize([NULL], [NULL], [NULL]);) 2025.11.13 09:23:33.331401 [ 16233 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:23:33.397768 [ 16233 ] {aa61b6ec-c17f-4d55-a252-835f10ad96ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 796, line 797) (in query: SELECT length([NULL], [NULL], [NULL]);) 2025.11.13 09:23:33.414158 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:33.481187 [ 16233 ] {a418cf0c-e8a8-436e-b2fb-9ff7abe8706f} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 797, line 798) (in query: SELECT lengthUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:33.578095 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:33.729338 [ 16233 ] {dff83337-11b1-4fb7-bca3-ede499ead2ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 798, line 799) (in query: SELECT less([NULL], [NULL], [NULL]);) 2025.11.13 09:23:33.763235 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:33.825891 [ 16233 ] {58bebb80-15bc-4a65-beb9-fa340a039e21} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 799, line 800) (in query: SELECT lessOrEquals([NULL], [NULL], [NULL]);) 2025.11.13 09:23:33.838926 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:33.861413 [ 17388 ] {a733c3cb-ad82-452f-8986-267de599466c} executeQuery: Code: 60. DB::Exception: Table test_13.replica_01108_2_tmp does not exist. Maybe you meant test_13.replica_01108_2?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60978) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM RESTART REPLICA replica_01108_2_tmp), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:920: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x00000000339191f2 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:984: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x0000000033913629 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:761: DB::InterpreterSystemQuery::execute() @ 0x00000000338e038e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:33.964416 [ 17388 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.replica_01108_2_tmp does not exist. Maybe you meant test_13.replica_01108_2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:920: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x00000000339191f2 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:984: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x0000000033913629 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:761: DB::InterpreterSystemQuery::execute() @ 0x00000000338e038e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:34.060629 [ 16233 ] {fca241ff-56de-4c97-9271-d52a1dec62aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 800, line 801) (in query: SELECT levenshteinDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:23:34.090750 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:34.209014 [ 16233 ] {77edd8ec-e338-415c-9d43-4744bf8743fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 801, line 802) (in query: SELECT levenshteinDistanceUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:34.222854 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:34.330567 [ 16233 ] {a26a4438-3d69-4ecd-98c6-1adb47c1f5cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 802, line 803) (in query: SELECT lgamma([NULL], [NULL], [NULL]);) 2025.11.13 09:23:34.344925 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:34.540683 [ 16233 ] {be51f674-5ea6-40a3-81b6-c563e9aef8c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 803, line 804) (in query: SELECT like([NULL], [NULL], [NULL]);) 2025.11.13 09:23:34.569344 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:34.625224 [ 16233 ] {a0d1f52f-abe8-40c1-8213-608468d48446} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 804, line 805) (in query: SELECT ln([NULL], [NULL], [NULL]);) 2025.11.13 09:23:34.644105 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:34.729625 [ 16233 ] {1344598d-48e7-4fc2-b456-aa93800f540f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function locate: In scope SELECT locate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 805, line 806) (in query: SELECT locate([NULL], [NULL], [NULL]);) 2025.11.13 09:23:34.751965 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function locate: In scope SELECT locate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:34.881462 [ 16233 ] {333c4bc7-0971-4f3e-aaf9-d880a9348d1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 806, line 807) (in query: SELECT log([NULL], [NULL], [NULL]);) 2025.11.13 09:23:34.899721 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:34.935659 [ 5639 ] {acd5e75e-ae43-45bc-b7f4-7390661c9d52} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34610) (comment: 02534_keyed_siphash.sql) (query 195, line 268) (in query: select sipHash64Keyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e353e 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926808b 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009267992 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:23:34.964239 [ 16233 ] {d56c25ac-4935-4218-be7c-21afc5b93578} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 807, line 808) (in query: SELECT log10([NULL], [NULL], [NULL]);) 2025.11.13 09:23:34.991335 [ 5639 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e353e 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000926808b 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009267992 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:23:35.021235 [ 18728 ] {378699a3-84f2-4ec7-b0bd-6a7dd52b2092} executeQuery: Code: 60. DB::Exception: Table test_01516_test_1.data3 (5793af1d-0312-4247-8206-cc5b8bde37cb) does not exist. Maybe you meant data1?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:32778) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_01516_test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031ade1f4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:447: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73601 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:35.035182 [ 18728 ] {} TCPHandler: Code: 60. DB::Exception: Table test_01516_test_1.data3 (5793af1d-0312-4247-8206-cc5b8bde37cb) does not exist. Maybe you meant data1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031ade1f4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:447: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73601 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:35.051323 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:35.238679 [ 16233 ] {4224d739-09f0-4709-ba40-6957a3b5e7ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 808, line 809) (in query: SELECT log1p([NULL], [NULL], [NULL]);) 2025.11.13 09:23:35.255358 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:35.324201 [ 16233 ] {4ce5b6ce-561f-4c05-b451-85059f314781} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 809, line 810) (in query: SELECT log2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:35.337763 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:35.403255 [ 16233 ] {84ae64bb-35ec-41e8-ba79-a1a2bbda5301} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 810, line 811) (in query: SELECT logTrace([NULL], [NULL], [NULL]);) 2025.11.13 09:23:35.417117 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:35.488039 [ 16233 ] {37c0e322-ff33-46bf-b46e-37aa61d9af0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 811, line 812) (in query: SELECT lowCardinalityIndices([NULL], [NULL], [NULL]);) 2025.11.13 09:23:35.628407 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:35.777638 [ 16233 ] {50e84c49-1844-4d9b-b72f-8f7f63210974} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 812, line 813) (in query: SELECT lowCardinalityKeys([NULL], [NULL], [NULL]);) 2025.11.13 09:23:35.791447 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:35.866637 [ 16233 ] {5e15dbd9-6997-43dd-88e2-cb35365738d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 813, line 814) (in query: SELECT lower([NULL], [NULL], [NULL]);) 2025.11.13 09:23:35.881989 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:35.954213 [ 16233 ] {c72fc84a-a2b1-457d-aa7c-ab89c50a3188} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 814, line 815) (in query: SELECT lowerUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:35.968151 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:36.142615 [ 16233 ] {c8b41205-8e9a-4190-91c1-377761e28f33} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPad, should be string: In scope SELECT lpad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 815, line 816) (in query: SELECT lpad([NULL], [NULL], [NULL]);) 2025.11.13 09:23:36.155727 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPad, should be string: In scope SELECT lpad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:36.231673 [ 16233 ] {3bcc9527-06fc-47e2-abf7-d2bd7078ffd3} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 816, line 818) (in query: SELECT lttb([NULL], [NULL], [NULL]);) 2025.11.13 09:23:36.246618 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:36.323174 [ 16233 ] {33fc976e-e2d6-410f-ad5f-e74e8d4e584d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT makeDate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 817, line 819) (in query: SELECT makeDate([NULL], [NULL], [NULL]);) 2025.11.13 09:23:36.337762 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT makeDate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:36.367152 [ 16354 ] {e9a803e0-9289-4c8f-b808-ab628bafe226} executeQuery: Code: 60. DB::Exception: Table test_13.replica_01108_3_tmp does not exist. Maybe you meant test_13.replica_01108_3?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:32850) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM RESTART REPLICA replica_01108_3_tmp), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:920: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x00000000339191f2 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:984: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x0000000033913629 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:761: DB::InterpreterSystemQuery::execute() @ 0x00000000338e038e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:36.380664 [ 16354 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.replica_01108_3_tmp does not exist. Maybe you meant test_13.replica_01108_3?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:920: DB::InterpreterSystemQuery::doRestartReplica(DB::StorageID const&, std::shared_ptr, bool) @ 0x00000000339191f2 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:984: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x0000000033913629 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:761: DB::InterpreterSystemQuery::execute() @ 0x00000000338e038e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:36.398853 [ 16233 ] {f9031bb6-7e66-488e-8287-f873c6339349} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT makeDate32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 818, line 820) (in query: SELECT makeDate32([NULL], [NULL], [NULL]);) 2025.11.13 09:23:36.413590 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT makeDate32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:36.507181 [ 16233 ] {9679554e-6610-47a8-bfbc-0755ef15ad16} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 3 arguments: In scope SELECT makeDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 819, line 821) (in query: SELECT makeDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:23:36.522612 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 3 arguments: In scope SELECT makeDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:36.578999 [ 16233 ] {bce0a1ad-6fb4-41e0-a14a-48f4ddea57d9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 3 arguments: In scope SELECT makeDateTime64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 820, line 822) (in query: SELECT makeDateTime64([NULL], [NULL], [NULL]);) 2025.11.13 09:23:36.594916 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 3 arguments: In scope SELECT makeDateTime64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:36.659233 [ 16233 ] {9c791503-f681-4075-a70a-fe67023fd99b} executeQuery: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 821, line 823) (in query: SELECT mannWhitneyUTest([NULL], [NULL], [NULL]);) 2025.11.13 09:23:36.672915 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:36.768321 [ 5639 ] {1a82e6fa-baeb-4161-ac0f-4a664a7e2cc4} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34610) (comment: 02534_keyed_siphash.sql) (query 196, line 269) (in query: select sipHash128Keyed(toUInt64(0), '1');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e353e 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093bb88a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093bb012 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:23:36.777925 [ 5639 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed(toUInt64(0), '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::impl::parseSipHashKeyColumns(DB::ColumnWithTypeAndName const&) @ 0x00000000091e353e 5. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093bb88a 6. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 7. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000093bb012 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 9. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 30. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 31. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 2025.11.13 09:23:36.850567 [ 16233 ] {7c605421-4199-4fb9-b5fe-0b598cf773a4} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 822, line 824) (in query: SELECT map([NULL], [NULL], [NULL]);) 2025.11.13 09:23:36.864640 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:37.051697 [ 16233 ] {0983acbb-d474-493c-a288-bdfeb75ca43e} executeQuery: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 823, line 825) (in query: SELECT mapAdd([NULL], [NULL], [NULL]);) 2025.11.13 09:23:37.080743 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:37.257323 [ 16233 ] {7f16158f-d2c0-42e2-86b6-18c2fe505929} executeQuery: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 824, line 826) (in query: SELECT mapAll([NULL], [NULL], [NULL]);) 2025.11.13 09:23:37.275030 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:37.330000 [ 16233 ] {05f31e2c-be59-40db-b0b2-61ce83a191e9} executeQuery: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 825, line 827) (in query: SELECT mapApply([NULL], [NULL], [NULL]);) 2025.11.13 09:23:37.342833 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:37.422748 [ 16233 ] {ea8cc4d2-39c9-4a90-ada8-43a5ab0b1762} executeQuery: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 826, line 828) (in query: SELECT mapConcat([NULL], [NULL], [NULL]);) 2025.11.13 09:23:37.441763 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:37.515026 [ 16233 ] {c344b6dd-fcf8-4e03-9d77-5ef2c5aff1f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 827, line 829) (in query: SELECT mapContains([NULL], [NULL], [NULL]);) 2025.11.13 09:23:37.547951 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:37.610972 [ 16233 ] {877c8fba-d904-4888-9046-b0089fddd109} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContainsKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapContainsKeyLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 828, line 830) (in query: SELECT mapContainsKeyLike([NULL], [NULL], [NULL]);) 2025.11.13 09:23:37.625986 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContainsKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapContainsKeyLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:37.772743 [ 16233 ] {c3bc3248-bf97-4597-845f-259ef3c1032a} executeQuery: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 829, line 831) (in query: SELECT mapExists([NULL], [NULL], [NULL]);) 2025.11.13 09:23:37.788865 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:37.930576 [ 16233 ] {d1c440bc-8178-442a-819e-9240baaf9bae} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapExtractKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapExtractKeyLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 830, line 832) (in query: SELECT mapExtractKeyLike([NULL], [NULL], [NULL]);) 2025.11.13 09:23:37.947969 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapExtractKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapExtractKeyLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:38.111773 [ 16233 ] {d0416698-2c60-4a15-8990-088221e5c7cf} executeQuery: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 831, line 833) (in query: SELECT mapFilter([NULL], [NULL], [NULL]);) 2025.11.13 09:23:38.129730 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:38.220711 [ 19606 ] {89f14fa3-dd0a-4e8b-9993-8b65ce5dddb1} executeQuery: Code: 57. DB::Exception: Table test_13.replica_01108_2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:32956) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: RENAME TABLE replica_01108_1_tmp TO replica_01108_2, replica_01108_2_tmp TO replica_01108_3, replica_01108_3_tmp TO replica_01108_4, replica_01108_4_tmp TO replica_01108_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002ea4fcea 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:791: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031aef5ef 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032afdc4f 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:23:38.224666 [ 16233 ] {941cd609-7741-4225-82a7-0c2b96be5982} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 832, line 834) (in query: SELECT mapFromArrays([NULL], [NULL], [NULL]);) 2025.11.13 09:23:38.253554 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:38.305826 [ 19606 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.replica_01108_2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::StorageID const&) @ 0x000000002ea4fcea 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:791: DB::DatabaseCatalog::assertTableDoesntExist(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031aef5ef 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:112: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000032afdc4f 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:81: DB::InterpreterRenameQuery::execute() @ 0x0000000032af955d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:23:38.315912 [ 16233 ] {867d7b20-d0e9-4654-b422-1457c87d4db5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT mapFromString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 833, line 835) (in query: SELECT mapFromString([NULL], [NULL], [NULL]);) 2025.11.13 09:23:38.423757 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT mapFromString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:38.558040 [ 16233 ] {c9c48457-445e-4d69-b42c-ccec51213a11} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 834, line 836) (in query: SELECT mapKeys([NULL], [NULL], [NULL]);) 2025.11.13 09:23:38.608606 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:38.697552 [ 16233 ] {3715595c-f9ef-4e97-89cf-ef36d0e6d26c} executeQuery: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 835, line 837) (in query: SELECT mapPartialReverseSort([NULL], [NULL], [NULL]);) 2025.11.13 09:23:38.711647 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:38.976178 [ 16233 ] {fca74d3c-b624-4853-b52f-46e2194dab28} executeQuery: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 836, line 838) (in query: SELECT mapPartialSort([NULL], [NULL], [NULL]);) 2025.11.13 09:23:39.009271 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:39.075042 [ 16233 ] {59a61011-ae63-4e0a-be6a-7dea3594b358} executeQuery: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type Nullable(Nothing): In scope SELECT mapPopulateSeries([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 837, line 839) (in query: SELECT mapPopulateSeries([NULL], [NULL], [NULL]);) 2025.11.13 09:23:39.090576 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type Nullable(Nothing): In scope SELECT mapPopulateSeries([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:39.232790 [ 16233 ] {996677ca-6e7c-47f2-ab53-558e0782e5b9} executeQuery: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 838, line 840) (in query: SELECT mapReverseSort([NULL], [NULL], [NULL]);) 2025.11.13 09:23:39.245868 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:39.310563 [ 16233 ] {e805891c-a598-4814-83c4-801f9aeaae6d} executeQuery: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 839, line 841) (in query: SELECT mapSort([NULL], [NULL], [NULL]);) 2025.11.13 09:23:39.341936 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:39.405717 [ 16233 ] {2be9d33d-752c-4a9e-be9c-ff8a9e697d0c} executeQuery: Code: 43. DB::Exception: mapSubtract only accepts maps: In scope SELECT mapSubtract([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 840, line 842) (in query: SELECT mapSubtract([NULL], [NULL], [NULL]);) 2025.11.13 09:23:39.509676 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: mapSubtract only accepts maps: In scope SELECT mapSubtract([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:39.635622 [ 16233 ] {0413dc5a-c776-4b71-8e67-52c6a7ef55be} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 841, line 843) (in query: SELECT mapUpdate([NULL], [NULL], [NULL]);) 2025.11.13 09:23:39.666052 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:39.727598 [ 16233 ] {e73ce2c1-295a-4a28-b85f-dd2ee39f411b} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 842, line 844) (in query: SELECT mapValues([NULL], [NULL], [NULL]);) 2025.11.13 09:23:39.833297 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:39.946783 [ 16233 ] {011d7b22-1aab-435b-b21f-c8695aa90a99} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 843, line 845) (in query: SELECT match([NULL], [NULL], [NULL]);) 2025.11.13 09:23:40.019735 [ 6072 ] {66b3629f-fb10-4027-a2c8-a6f908f1603f} executeQuery: Code: 60. DB::Exception: Table test_13.replica_01108_1 does not exist. Maybe you meant test_13.replica_01108_1_tmp?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33012) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM SYNC REPLICA replica_01108_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1258: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003390a222 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x00000000338e099f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:40.034041 [ 6072 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.replica_01108_1 does not exist. Maybe you meant test_13.replica_01108_1_tmp?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1258: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003390a222 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x00000000338e099f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:40.051296 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:40.075000 [ 18391 ] {756eeb4e-7f51-410d-8022-23a63af250dd} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33036) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 1, line 1) (in query: select * from format(TSV, 'x UInt32, y UInt32', '1\t2\n\n') settings input_format_tsv_skip_trailing_empty_lines=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b9e0ebd 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b426f82 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:23:40.083554 [ 18391 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b9e0ebd 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b426f82 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:23:40.177056 [ 16233 ] {84ef869c-0279-4c25-9a3e-c54a91920490} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 844, line 846) (in query: SELECT materialize([NULL], [NULL], [NULL]);) 2025.11.13 09:23:40.191739 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:40.268750 [ 16233 ] {5c4d11bf-aed7-44c4-b0c8-112541855379} executeQuery: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 845, line 847) (in query: SELECT max([NULL], [NULL], [NULL]);) 2025.11.13 09:23:40.284842 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:40.450181 [ 16233 ] {4914a835-4a6e-4a01-8c2e-383c1551d03b} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 846, line 848) (in query: SELECT max2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:40.464550 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:40.527115 [ 16233 ] {987d744a-c060-4e8c-b193-7b07096f513e} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 847, line 849) (in query: SELECT maxIntersections([NULL], [NULL], [NULL]);) 2025.11.13 09:23:40.540301 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:40.543726 [ 18391 ] {27e86a38-e005-4019-bc97-c5104ce0e18e} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n1\t2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33036) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 3, line 3) (in query: select * from format(TSV, 'x UInt32, y UInt32', '1\t2\n\n1\t2\n') settings input_format_tsv_skip_trailing_empty_lines=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b9e0ebd 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b426f82 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:23:40.605383 [ 16233 ] {2b2d8333-1f42-4b91-a639-cfa744f7471e} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 848, line 850) (in query: SELECT maxIntersectionsPosition([NULL], [NULL], [NULL]);) 2025.11.13 09:23:40.618706 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:40.608336 [ 18391 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n1\t2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing TabSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b9e0ebd 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b426f82 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:23:40.684979 [ 16233 ] {f87b5272-b874-48f0-a27c-aff61f1a3cf0} executeQuery: Code: 43. DB::Exception: Cannot calculate -Map of type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 849, line 851) (in query: SELECT maxMappedArrays([NULL], [NULL], [NULL]);) 2025.11.13 09:23:40.699161 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Cannot calculate -Map of type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:40.719937 [ 18391 ] {952fd93d-146d-44f5-968f-f7d29c96f0e4} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33036) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 4, line 5) (in query: select * from format(CSV, 'x UInt32, y UInt32', '1,2\n\n') settings input_format_csv_skip_trailing_empty_lines=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b4ec2b8 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43287e 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:23:40.776337 [ 18391 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b4ec2b8 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43287e 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:23:40.843935 [ 16233 ] {0062272a-7698-4239-ae62-126cfc70f136} executeQuery: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 850, line 852) (in query: SELECT meanZTest([NULL], [NULL], [NULL]);) 2025.11.13 09:23:40.914735 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:40.951143 [ 18391 ] {1338abeb-0eba-4abc-a9cd-b2883f24364a} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n1,2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "1,2" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33036) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 6, line 7) (in query: select * from format(CSV, 'x UInt32, y UInt32', '1,2\n\n1,2\n') settings input_format_csv_skip_trailing_empty_lines=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b4ec2b8 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43287e 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:23:40.960683 [ 18391 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected ',' before: '\n1,2\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "1,2" is not like UInt32 : While executing CSVRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x000000003b4ec2b8 5. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43287e 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 8. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 9. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 17. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:23:40.996408 [ 16233 ] {9437ca4d-873f-4803-a3dc-cf5d414816ce} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 851, line 853) (in query: SELECT median([NULL], [NULL], [NULL]);) 2025.11.13 09:23:41.020257 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:41.029555 [ 18391 ] {ecf54d1f-e4df-4219-8cd1-2e1c3f860e3b} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33036) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 7, line 9) (in query: select * from format(CustomSeparated, 'x UInt32, y UInt32', '1\t2\n\n\n') settings input_format_custom_skip_trailing_empty_lines=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001f9723b0 5. ./src/IO/ReadHelpers.h:219: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b58caf1 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e622 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 18. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:23:41.040339 [ 18391 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001f9723b0 5. ./src/IO/ReadHelpers.h:219: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b58caf1 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e622 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 18. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:23:41.136766 [ 16233 ] {173089f9-3fb8-48ce-bc43-2576a9edf750} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 852, line 854) (in query: SELECT medianBFloat16([NULL], [NULL], [NULL]);) 2025.11.13 09:23:41.153198 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:41.276211 [ 16233 ] {b9df4916-b626-40f7-8e32-e4d4708a0e74} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 853, line 855) (in query: SELECT medianBFloat16Weighted([NULL], [NULL], [NULL]);) 2025.11.13 09:23:41.296861 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:41.353299 [ 16354 ] {f142ce2d-353e-4df6-aae8-fe0c39fac69a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:32928) (comment: 02354_vector_search_expansion_search.sql) (query 4, line 13) (in query: -- Generate random values but with a fixed seed (conceptually), so that the data is deterministic. -- Unfortunately, no random functions in ClickHouse accepts a seed. Instead, abuse the numbers table + hash functions to provide -- deterministic randomness. INSERT INTO tab SELECT number, [sipHash64(number)/18446744073709551615, wyHash64(number)/18446744073709551615] FROM numbers(660000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexVectorSimilarity.cpp:329: DB::MergeTreeIndexAggregatorVectorSimilarity::update(DB::Block const&, unsigned long*, unsigned long) @ 0x0000000039db6c99 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:417: DB::MergeTreeDataPartWriterOnDisk::calculateAndSerializeSkipIndices(DB::Block const&, std::vector> const&) @ 0x0000000039bc77a2 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:219: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x0000000039ba9871 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:202: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba7015 11. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:23:41.375456 [ 16354 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=16, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x0000000026d55454 7. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexVectorSimilarity.cpp:329: DB::MergeTreeIndexAggregatorVectorSimilarity::update(DB::Block const&, unsigned long*, unsigned long) @ 0x0000000039db6c99 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:417: DB::MergeTreeDataPartWriterOnDisk::calculateAndSerializeSkipIndices(DB::Block const&, std::vector> const&) @ 0x0000000039bc77a2 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:219: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x0000000039ba9871 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:202: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba7015 11. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:23:41.465330 [ 18391 ] {d5fe0579-c8e4-496f-b626-8403fcb55d1d} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n1\t2\n\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33036) (comment: 02771_tsv_csv_custom_skip_trailing_empty_lines.sql) (query 9, line 11) (in query: select * from format(CustomSeparated, 'x UInt32, y UInt32', '1\t2\n\n\n1\t2\n\n\n') settings input_format_custom_skip_trailing_empty_lines=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001f9723b0 5. ./src/IO/ReadHelpers.h:219: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b58caf1 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e622 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 18. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:23:41.473494 [ 18391 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '\t' before: '\n\n1\t2\n\n\n': (at row 2) : Row 1: Column 0, name: x, type: UInt32, parsed text: "1" Column 1, name: y, type: UInt32, parsed text: "2" Row 2: Column 0, name: x, type: UInt32, ERROR: text "12" is not like UInt32 : While executing CustomSeparatedRowInputFormat. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001f971a68 4. ./build_docker/./src/IO/ReadHelpers.cpp:131: DB::assertString(char const*, DB::ReadBuffer&) @ 0x000000001f9723b0 5. ./src/IO/ReadHelpers.h:219: DB::CustomSeparatedFormatReader::skipFieldDelimiter() @ 0x000000003b58caf1 6. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b43e622 7. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 8. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 9. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 10. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 16. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 17. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 18. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:23:41.487126 [ 16233 ] {fd5fb90d-b78f-494f-8a8c-8f4a03260f5a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 854, line 856) (in query: SELECT medianDD([NULL], [NULL], [NULL]);) 2025.11.13 09:23:41.500712 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:41.569384 [ 16233 ] {58b3094a-b9d0-46c6-aacf-95e5ada2e665} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 855, line 857) (in query: SELECT medianDeterministic([NULL], [NULL], [NULL]);) 2025.11.13 09:23:41.585254 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:41.659854 [ 16233 ] {451eb523-9bb7-4911-b5f4-cfc917869c77} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 856, line 858) (in query: SELECT medianExact([NULL], [NULL], [NULL]);) 2025.11.13 09:23:41.677246 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:41.758291 [ 16233 ] {3faa9e41-40e7-42b8-ab02-440922fb6cee} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 857, line 859) (in query: SELECT medianExactHigh([NULL], [NULL], [NULL]);) 2025.11.13 09:23:41.791327 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:41.844425 [ 16233 ] {37f908cd-6caa-4443-bd21-a8a963bf504b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 858, line 860) (in query: SELECT medianExactLow([NULL], [NULL], [NULL]);) 2025.11.13 09:23:41.858358 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:41.939985 [ 16233 ] {6bd6e26d-f4f6-44ae-8b04-a23b11841c66} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 859, line 861) (in query: SELECT medianExactWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:23:41.954230 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:41.967330 [ 18391 ] {9aa3ccbb-5faa-40ba-8ad6-19c84e58c7ee} executeQuery: Code: 60. DB::Exception: Table test_13.replica_01108_2 does not exist. Maybe you meant test_13.replica_01108_2_tmp?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43550) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM SYNC REPLICA replica_01108_2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1258: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003390a222 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x00000000338e099f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:41.981036 [ 18391 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.replica_01108_2 does not exist. Maybe you meant test_13.replica_01108_2_tmp?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1258: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003390a222 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x00000000338e099f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:42.098619 [ 16233 ] {35ea39c9-827b-4b81-bf86-43c9d87f4d1e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 860, line 862) (in query: SELECT medianExactWeightedInterpolated([NULL], [NULL], [NULL]);) 2025.11.13 09:23:42.112126 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:42.218517 [ 15982 ] {a85fd8c4-f3fa-4210-b810-d3ce22f06a64} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33028) (comment: 01505_trivial_count_with_partition_predicate.sql) (query 10, line 14) (in query: -- non-optimized (toDate(DateTime) is always monotonic, but we cannot relaxing the predicates to do trivial count()) select count() from test1 where p > toDateTime('2020-09-01 10:00:00');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:42.228967 [ 15982 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 3.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:42.339949 [ 16233 ] {dbe2e3a9-02db-4326-87d9-b0f6e2f86db0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 861, line 863) (in query: SELECT medianGK([NULL], [NULL], [NULL]);) 2025.11.13 09:23:42.353808 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:42.422936 [ 16233 ] {e7ac211c-dcc0-4900-ae74-53433f663c4c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 862, line 864) (in query: SELECT medianInterpolatedWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:23:42.440507 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:42.525589 [ 16233 ] {0cf59a92-2990-4d3e-874a-1222c5127354} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 863, line 865) (in query: SELECT medianTDigest([NULL], [NULL], [NULL]);) 2025.11.13 09:23:42.573268 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:42.670383 [ 16233 ] {257d5b54-979c-4692-9697-c94b7d06fd71} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 864, line 866) (in query: SELECT medianTDigestWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:23:42.789739 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:42.911371 [ 16233 ] {c487c20f-e922-4944-b8d0-8bbe788a6210} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 865, line 867) (in query: SELECT medianTiming([NULL], [NULL], [NULL]);) 2025.11.13 09:23:42.924752 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:43.099202 [ 16233 ] {28482c7c-d404-45f0-ad0a-6d49445ed7b4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 866, line 868) (in query: SELECT medianTimingWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:23:43.123246 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:43.430878 [ 16233 ] {9846a05d-92ff-4eff-b88f-346bcbee67bf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT mid([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 868, line 870) (in query: SELECT mid([NULL], [NULL], [NULL]);) 2025.11.13 09:23:43.456285 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT mid([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:43.507105 [ 16233 ] {818ffe16-df49-4d78-b8c3-6ed30cae71de} executeQuery: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 869, line 871) (in query: SELECT min([NULL], [NULL], [NULL]);) 2025.11.13 09:23:43.521878 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:43.582221 [ 16233 ] {33f90cfc-f874-4421-b8d8-d88b9cc649a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 870, line 872) (in query: SELECT min2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:43.595059 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:43.745465 [ 16233 ] {2ef43c24-311d-4ab8-866b-0727ac390609} executeQuery: Code: 43. DB::Exception: Cannot calculate -Map of type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 871, line 873) (in query: SELECT minMappedArrays([NULL], [NULL], [NULL]);) 2025.11.13 09:23:43.750411 [ 15982 ] {7e398bff-8572-418e-9d61-61dec08ea4ed} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33028) (comment: 01505_trivial_count_with_partition_predicate.sql) (query 12, line 18) (in query: select count() FROM test1 where toDate(p) = '2020-09-01' and sipHash64(toString(toDate(p))) % 2 = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:43.759684 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Cannot calculate -Map of type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:43.763889 [ 15982 ] {} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00, current rows: 2.00. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x000000002f2f6c57 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x000000002f2f272e 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:72: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x000000002f2f2b6c 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:327: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000003c267d63 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2172: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c7b57 8. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:43.905218 [ 16233 ] {33ec11e7-e400-4c4e-a8bb-d2fc7c7b2c18} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 872, line 874) (in query: SELECT minSampleSizeContinous([NULL], [NULL], [NULL]);) 2025.11.13 09:23:43.919673 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:44.047974 [ 16605 ] {e740c48e-ff22-4ef2-a182-f265f1a2573f} executeQuery: Code: 60. DB::Exception: Table test_13.replica_01108_3 does not exist. Maybe you meant test_13.replica_01108_3_tmp?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43654) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM SYNC REPLICA replica_01108_3), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1258: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003390a222 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x00000000338e099f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:44.064281 [ 16605 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.replica_01108_3 does not exist. Maybe you meant test_13.replica_01108_3_tmp?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1258: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003390a222 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x00000000338e099f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:44.075632 [ 16233 ] {71cb9ab7-7007-42a8-b2c1-a0687cf101b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 873, line 875) (in query: SELECT minSampleSizeContinuous([NULL], [NULL], [NULL]);) 2025.11.13 09:23:44.106533 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:44.216617 [ 16233 ] {25d758bb-f244-4033-8ac1-4ae252c28438} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 874, line 876) (in query: SELECT minSampleSizeConversion([NULL], [NULL], [NULL]);) 2025.11.13 09:23:44.231926 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:44.297197 [ 16233 ] {85ec650c-f03c-4676-a99e-9f32c69eb660} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 875, line 877) (in query: SELECT minus([NULL], [NULL], [NULL]);) 2025.11.13 09:23:44.312377 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:44.385138 [ 16233 ] {e8b2a275-4485-4b36-8480-e3ea2eef6be7} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 876, line 878) (in query: SELECT mismatches([NULL], [NULL], [NULL]);) 2025.11.13 09:23:44.396956 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:44.458061 [ 16233 ] {0be7633b-690a-418f-8d45-a17b8215db63} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 877, line 879) (in query: SELECT mod([NULL], [NULL], [NULL]);) 2025.11.13 09:23:44.471661 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:44.576048 [ 16233 ] {80956fcc-e81d-4aa9-881d-43eb706e4f68} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 878, line 880) (in query: SELECT modulo([NULL], [NULL], [NULL]);) 2025.11.13 09:23:44.588321 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:44.714023 [ 16233 ] {b3fce93b-5741-4d6e-8041-8eea71f600ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 879, line 881) (in query: SELECT moduloLegacy([NULL], [NULL], [NULL]);) 2025.11.13 09:23:44.726739 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:44.783357 [ 16233 ] {18394c9b-d454-4521-b151-62a586beb7e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 880, line 882) (in query: SELECT moduloOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:23:44.795992 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:44.858284 [ 16233 ] {7bc3abf6-f5d0-47b8-9749-0c71aab5d688} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 881, line 883) (in query: SELECT monthName([NULL], [NULL], [NULL]);) 2025.11.13 09:23:44.874564 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:44.938719 [ 16233 ] {30074a8e-742e-48e7-908e-da2b04d74cce} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 882, line 884) (in query: SELECT mortonDecode([NULL], [NULL], [NULL]);) 2025.11.13 09:23:44.952451 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:45.009736 [ 16233 ] {bda07a7c-21dc-440d-93e4-621ddb43eaab} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 883, line 885) (in query: SELECT mortonEncode([NULL], [NULL], [NULL]);) 2025.11.13 09:23:45.025335 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:45.139763 [ 16233 ] {7ea75b32-cf82-4a52-864a-579dc16e720a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAllIndices: In scope SELECT multiFuzzyMatchAllIndices([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 884, line 886) (in query: SELECT multiFuzzyMatchAllIndices([NULL], [NULL], [NULL]);) 2025.11.13 09:23:45.155926 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAllIndices: In scope SELECT multiFuzzyMatchAllIndices([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:45.224285 [ 16233 ] {343809fb-12b7-49ca-8423-95a188e3e22a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 885, line 887) (in query: SELECT multiFuzzyMatchAny([NULL], [NULL], [NULL]);) 2025.11.13 09:23:45.239743 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:45.311176 [ 16233 ] {063a46a9-fd10-46c3-aba4-c3445d42f368} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAnyIndex: In scope SELECT multiFuzzyMatchAnyIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 886, line 888) (in query: SELECT multiFuzzyMatchAnyIndex([NULL], [NULL], [NULL]);) 2025.11.13 09:23:45.327716 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAnyIndex: In scope SELECT multiFuzzyMatchAnyIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:45.408428 [ 16233 ] {f4c0f9ea-029d-4813-ac44-a940b0278aae} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT multiIf([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 887, line 889) (in query: SELECT multiIf([NULL], [NULL], [NULL]);) 2025.11.13 09:23:45.423912 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT multiIf([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:45.582099 [ 16233 ] {1e02eb3e-cd9d-4369-ac4d-2907e9e5b005} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 888, line 890) (in query: SELECT multiMatchAllIndices([NULL], [NULL], [NULL]);) 2025.11.13 09:23:45.630421 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:45.692853 [ 16233 ] {d5fd09dc-f100-44c7-85d3-e2cb77ddb8a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 889, line 891) (in query: SELECT multiMatchAny([NULL], [NULL], [NULL]);) 2025.11.13 09:23:45.705927 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:45.756150 [ 16233 ] {4a9773d8-8ef6-4a01-8c34-f09f2a1c596b} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 890, line 892) (in query: SELECT multiMatchAnyIndex([NULL], [NULL], [NULL]);) 2025.11.13 09:23:45.767640 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:45.836430 [ 16233 ] {42a59999-f258-410b-b9ed-3bc088ae1ace} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 891, line 893) (in query: SELECT multiSearchAllPositions([NULL], [NULL], [NULL]);) 2025.11.13 09:23:45.851296 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:45.946749 [ 16233 ] {3bcc68c0-2650-4112-9660-d9e4ce406c35} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 892, line 894) (in query: SELECT multiSearchAllPositionsCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:45.960437 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:46.028451 [ 16230 ] {51c8e666-56be-40ba-b423-b5063d76fa83} executeQuery: Code: 60. DB::Exception: Table test_13.replica_01108_4 does not exist. Maybe you meant test_13.replica_01108_4_tmp?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43712) (comment: 01108_restart_replicas_rename_deadlock_zookeeper.sh) (query 1, line 1) (in query: SYSTEM SYNC REPLICA replica_01108_4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1258: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003390a222 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x00000000338e099f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:46.043082 [ 16230 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.replica_01108_4 does not exist. Maybe you meant test_13.replica_01108_4_tmp?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1258: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003390a222 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x00000000338e099f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:23:46.097603 [ 16233 ] {87f17ad8-b353-40de-8a65-95dd4b57c079} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 893, line 895) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:46.113944 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:46.179097 [ 16233 ] {4bfa3ac9-1a40-41ed-abf9-fe3eba31c2d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 894, line 896) (in query: SELECT multiSearchAllPositionsUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:46.191584 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:46.299104 [ 16233 ] {0ffda33e-35e0-4c54-9388-104d13bd3047} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 895, line 897) (in query: SELECT multiSearchAny([NULL], [NULL], [NULL]);) 2025.11.13 09:23:46.382791 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:46.440938 [ 16233 ] {c8ee90e4-ba97-4787-8d31-3ba5fa40cf02} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 896, line 898) (in query: SELECT multiSearchAnyCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:46.520776 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:46.581742 [ 16233 ] {23bbdd80-06ea-46bd-8bf5-287994e3ba9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 897, line 899) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:46.617661 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:46.682226 [ 16233 ] {c12d3778-86ae-4142-afab-7d0ecb0f5bf2} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 898, line 900) (in query: SELECT multiSearchAnyUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:46.696628 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:46.764474 [ 16233 ] {a6052b4d-53e9-482b-9aa2-76a2b42a4976} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 899, line 901) (in query: SELECT multiSearchFirstIndex([NULL], [NULL], [NULL]);) 2025.11.13 09:23:46.780515 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:46.891940 [ 16233 ] {c5c37664-dbed-437f-b67c-8c8b37554116} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 900, line 902) (in query: SELECT multiSearchFirstIndexCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:46.907116 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:47.094269 [ 16233 ] {c2530c0d-1394-499f-b53c-9913f77f41f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 901, line 903) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:47.108338 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:47.182117 [ 16233 ] {f1adc9ff-b032-479a-a0ce-419eb722def3} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 902, line 904) (in query: SELECT multiSearchFirstIndexUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:47.199398 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:47.263759 [ 16233 ] {4c7edaec-d003-402f-80c2-9f8b322b322c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 903, line 905) (in query: SELECT multiSearchFirstPosition([NULL], [NULL], [NULL]);) 2025.11.13 09:23:47.277149 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:47.343634 [ 16233 ] {4958ba19-5c1f-4e54-8c2c-a6088cb68279} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 904, line 906) (in query: SELECT multiSearchFirstPositionCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:47.360703 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:47.512830 [ 16233 ] {d53a6c7d-6855-4c55-86d7-47b8a417d13f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 905, line 907) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:47.539457 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:47.760935 [ 3729 ] {6a662d59-1aed-452f-a26f-adffc7fb5393::all_1_6_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 236. DB::Exception: Cancelled merging parts: While executing MergeTreeSequentialSource. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x000000003978b547 5. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1924: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x00000000397d7cbf 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000398163f4 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::Progress const&) @ 0x000000003981613f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f266203 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fdc97 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 12. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 14. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 17. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:47.769903 [ 16233 ] {77aaaeaa-750a-45d8-8530-c74af2aac29f} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 906, line 908) (in query: SELECT multiSearchFirstPositionUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:47.811516 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:47.866233 [ 16233 ] {783c1079-3b50-41eb-bfb4-6eb5190b517e} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 907, line 909) (in query: SELECT multiply([NULL], [NULL], [NULL]);) 2025.11.13 09:23:47.880070 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:47.918048 [ 16198 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:47.946617 [ 16233 ] {7b4db397-8b83-4a76-8014-98ffd9c6bf6c} executeQuery: Code: 43. DB::Exception: Arguments for multiplyDecimal function must be Decimal: In scope SELECT multiplyDecimal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 908, line 910) (in query: SELECT multiplyDecimal([NULL], [NULL], [NULL]);) 2025.11.13 09:23:47.960926 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Arguments for multiplyDecimal function must be Decimal: In scope SELECT multiplyDecimal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:49.096206 [ 16233 ] {aee6ff90-d935-4784-a115-3d407ee4c6f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 914, line 916) (in query: SELECT negate([NULL], [NULL], [NULL]);) 2025.11.13 09:23:49.109928 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:49.173808 [ 16233 ] {8b642414-d41a-4bac-a87e-d89dfda2b4fa} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 915, line 917) (in query: SELECT neighbor([NULL], [NULL], [NULL]);) 2025.11.13 09:23:49.189506 [ 16233 ] {} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:23:49.256816 [ 16233 ] {8dd9d052-69f8-400e-80b1-81ed148a5c72} executeQuery: Code: 36. DB::Exception: First argument for function nested must be constant column with array of strings: In scope SELECT nested([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 916, line 918) (in query: SELECT nested([NULL], [NULL], [NULL]);) 2025.11.13 09:23:49.271669 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: First argument for function nested must be constant column with array of strings: In scope SELECT nested([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.11.13 09:23:49.400949 [ 16233 ] {92d10c04-5d91-491b-947c-9a6fd62d50fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 917, line 919) (in query: SELECT netloc([NULL], [NULL], [NULL]);) 2025.11.13 09:23:49.415399 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:49.614898 [ 16233 ] {9ebe59c8-e63d-489c-9fb1-b77753c8385a} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 918, line 920) (in query: SELECT ngramDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:23:49.720221 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:49.783140 [ 16233 ] {2b47dad5-e4a6-4893-8196-8cacdde376a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 919, line 921) (in query: SELECT ngramDistanceCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:49.799726 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:49.937341 [ 16233 ] {96257c26-fb24-4b5c-9fd6-7a50fd8168f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 920, line 922) (in query: SELECT ngramDistanceCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:49.979211 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:50.049141 [ 16233 ] {bba99ef3-b928-4ca6-ab6f-fc4a366f5855} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 921, line 923) (in query: SELECT ngramDistanceUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:50.061131 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:50.118097 [ 16233 ] {9dc06e76-8681-4da8-b50b-eef6ef447207} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 922, line 924) (in query: SELECT ngramMinHash([NULL], [NULL], [NULL]);) 2025.11.13 09:23:50.130733 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:50.216955 [ 16233 ] {ba8393b1-7dcf-4fc2-8c74-0264006976bc} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 923, line 925) (in query: SELECT ngramMinHashArg([NULL], [NULL], [NULL]);) 2025.11.13 09:23:50.231255 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:50.334786 [ 16233 ] {99d6e486-6a09-437b-9163-8f30b51f0e49} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 924, line 926) (in query: SELECT ngramMinHashArgCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:50.352684 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:50.413850 [ 16233 ] {71b3dfdf-7150-43a7-bb7f-7838753cf976} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 925, line 927) (in query: SELECT ngramMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:50.431332 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:50.578446 [ 16233 ] {e5f48450-b9fe-48a4-90b0-f8cdf502fe6c} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 926, line 928) (in query: SELECT ngramMinHashArgUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:50.591963 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:50.681367 [ 16233 ] {b53342c9-abb1-4145-a478-fad0bc52cb7e} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 927, line 929) (in query: SELECT ngramMinHashCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:50.696086 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:50.754886 [ 16233 ] {a8064f80-f0dd-4932-ac31-ef910cdbd313} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 928, line 930) (in query: SELECT ngramMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:50.808851 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:50.964950 [ 16233 ] {0f809874-c50e-46d6-b6d7-50da0181af67} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 929, line 931) (in query: SELECT ngramMinHashUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:50.978628 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:51.053733 [ 16233 ] {f070af43-50ea-4c3e-a4a2-ec57f5c134e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 930, line 932) (in query: SELECT ngramSearch([NULL], [NULL], [NULL]);) 2025.11.13 09:23:51.068326 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:51.256421 [ 16233 ] {3c27961e-c3d9-4419-80bd-5954e3ac9abc} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 931, line 933) (in query: SELECT ngramSearchCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:51.338816 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:51.402101 [ 16233 ] {2a31bdcd-5d51-4692-addd-15d296414fdc} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 932, line 934) (in query: SELECT ngramSearchCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:51.414456 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:51.492654 [ 16233 ] {838844ef-8242-4408-b7cb-d103dcfa2ea8} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 933, line 935) (in query: SELECT ngramSearchUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:51.506078 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:51.642477 [ 16233 ] {da72de6f-c17c-4273-9825-4e2936b25355} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 934, line 936) (in query: SELECT ngramSimHash([NULL], [NULL], [NULL]);) 2025.11.13 09:23:51.657854 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:51.715205 [ 19620 ] {bff35853-37c0-4cb4-a6a6-da4dbeddad5c} executeQuery: Code: 43. DB::Exception: Expected tuples of the same size as arguments of function tupleHammingDistance. Got Tuple(UInt8) and Tuple(UInt8, UInt8): In scope SELECT tupleHammingDistance(tuple(1), (1, 1)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43694) (comment: 01653_tuple_hamming_distance_2.sql) (query 19, line 21) (in query: SELECT tupleHammingDistance(tuple(1), tuple(1, 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionTupleHammingDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ae8cf2a 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:23:51.724631 [ 19620 ] {} TCPHandler: Code: 43. DB::Exception: Expected tuples of the same size as arguments of function tupleHammingDistance. Got Tuple(UInt8) and Tuple(UInt8, UInt8): In scope SELECT tupleHammingDistance(tuple(1), (1, 1)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionTupleHammingDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000001ae8cf2a 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:23:51.734936 [ 16233 ] {dd550ce0-6d4d-4cd8-9730-323acaad8b53} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 935, line 937) (in query: SELECT ngramSimHashCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:23:51.789341 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:51.842584 [ 16233 ] {36311c27-1ec4-460d-a441-d78343979d1a} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 936, line 938) (in query: SELECT ngramSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:51.855611 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:51.917672 [ 16233 ] {ec19f76f-9bea-4679-a4a0-03b16ea315c3} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 937, line 939) (in query: SELECT ngramSimHashUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:51.930604 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:52.073458 [ 16233 ] {2839ece9-ad5d-43d9-9720-0f858b634998} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 938, line 940) (in query: SELECT ngrams([NULL], [NULL], [NULL]);) 2025.11.13 09:23:52.122816 [ 5639 ] {66f40764-99ad-4154-bda5-b8adf65af688} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL SETTINGS enable_analyzer = 1. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34610) (comment: 02534_keyed_siphash.sql) (query 256, line 339) (in query: SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL SETTINGS enable_analyzer=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:23:52.132606 [ 5639 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT [(255, 1048575)], sipHash128ReferenceKeyed((toUInt64(2147483646), toUInt64(9223372036854775807)), ([(NULL, 100), (NULL, NULL), (1024, 10)], toUInt64(2), toUInt64(1024)), ''), hex(sipHash128ReferenceKeyed((-9223372036854775807, 1.), '-1', NULL)), ('', toUInt64(65535), [(9223372036854775807, 9223372036854775806)], toUInt64(65536)), arrayJoin((NULL, 65537, 255), [(NULL, NULL)]) GROUP BY tupleElement((NULL, NULL, NULL, -1), toUInt64(2), 2) = NULL SETTINGS enable_analyzer = 1. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:23:52.140635 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:52.243200 [ 16233 ] {b18cd214-6c20-4692-a157-641070627e14} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 939, line 941) (in query: SELECT nonNegativeDerivative([NULL], [NULL], [NULL]);) 2025.11.13 09:23:52.257853 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) 2025.11.13 09:23:52.365633 [ 16233 ] {9b7205f0-9ca7-444e-8d6e-2a1dd8c1c39b} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 940, line 942) (in query: SELECT normL1([NULL], [NULL], [NULL]);) 2025.11.13 09:23:52.380040 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:52.502804 [ 16233 ] {3e6b664d-6fd3-4951-9ab9-feba6243cdc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 941, line 943) (in query: SELECT normL2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:52.517027 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:52.627099 [ 16233 ] {9e9143c9-1b47-47be-9910-1c5730ebe2b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 942, line 944) (in query: SELECT normL2Squared([NULL], [NULL], [NULL]);) 2025.11.13 09:23:52.641119 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:52.719030 [ 16233 ] {567ab206-772e-42b8-a3bb-cc56672e80ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 943, line 945) (in query: SELECT normLinf([NULL], [NULL], [NULL]);) 2025.11.13 09:23:52.731724 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:52.794729 [ 16233 ] {673fbec4-843c-4331-9a7e-457fb6f9af6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 944, line 946) (in query: SELECT normLp([NULL], [NULL], [NULL]);) 2025.11.13 09:23:52.807829 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:52.878748 [ 16233 ] {9fee45fd-4a1e-4f98-b198-d12b51c49c93} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 945, line 947) (in query: SELECT normalizeL1([NULL], [NULL], [NULL]);) 2025.11.13 09:23:52.890965 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:52.947247 [ 16233 ] {d0bd3282-d7a1-4841-9363-bab9bc38c9c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 946, line 948) (in query: SELECT normalizeL2([NULL], [NULL], [NULL]);) 2025.11.13 09:23:52.961195 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.017596 [ 16233 ] {8ec5a234-b3c1-4579-be2b-e8d1c201b279} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 947, line 949) (in query: SELECT normalizeLinf([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.030725 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.186523 [ 16233 ] {0b373325-7b09-4aca-ae20-7b25c60472da} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 948, line 950) (in query: SELECT normalizeLp([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.202402 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.272536 [ 16233 ] {3199bd45-aedd-427e-86dc-2afe356ef193} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 949, line 951) (in query: SELECT normalizeQuery([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.286910 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.347350 [ 16233 ] {94b6599e-1119-4477-a9f4-3bbc183b860d} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 950, line 952) (in query: SELECT normalizeQueryKeepNames([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.361282 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.438183 [ 16233 ] {cd26cf8a-27a3-4cee-b006-64efacb034ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 951, line 953) (in query: SELECT normalizeUTF8NFC([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.451537 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.510822 [ 16233 ] {b215efd1-6feb-4137-9528-f6672daba4d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 952, line 954) (in query: SELECT normalizeUTF8NFD([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.514457 [ 19620 ] {2caedfb3-aaf8-4921-a707-47968d9bae59} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance(tuple(1), tuple('a')). (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43694) (comment: 01653_tuple_hamming_distance_2.sql) (query 20, line 22) (in query: SELECT tupleHammingDistance(tuple(1), tuple('a'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000174ede60 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000174a1a9c 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 12. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae8338b 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:23:53.523812 [ 19620 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance(tuple(1), tuple('a')). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000174ede60 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000174a1a9c 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 12. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae8338b 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:23:53.527969 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.580990 [ 19620 ] {2efbce66-e0e8-40ae-8e7b-edca841f5835} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance((1, 3), (3, 'a')). (NO_COMMON_TYPE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43694) (comment: 01653_tuple_hamming_distance_2.sql) (query 21, line 23) (in query: SELECT tupleHammingDistance((1, 3), (3, 'a'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000174ede60 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000174a1a9c 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 12. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae8338b 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:23:53.590235 [ 19620 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT tupleHammingDistance((1, 3), (3, 'a')). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x000000002f542fc2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x000000002f5519c0 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000174ede60 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000174a1a9c 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 11. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 12. DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ae8338b 13. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 16. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 2025.11.13 09:23:53.597594 [ 16233 ] {3e43e0ea-d6f8-4a50-bf4d-ae17800cb862} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 953, line 955) (in query: SELECT normalizeUTF8NFKC([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.610435 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.669258 [ 16233 ] {d9ba05c5-2a7a-4ca3-b523-ade2324a741e} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 954, line 956) (in query: SELECT normalizeUTF8NFKD([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.683582 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.773406 [ 16233 ] {7cb3d288-1d1f-43e5-ae02-d0025ce9ea51} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 955, line 957) (in query: SELECT normalizedQueryHash([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.786885 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.851665 [ 16233 ] {12a8ac33-d3fb-464d-8cc0-b186513bf9be} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 956, line 958) (in query: SELECT normalizedQueryHashKeepNames([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.918937 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:53.977564 [ 16233 ] {770a7287-6c41-4250-85ac-1b9e94c6f9ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 957, line 959) (in query: SELECT not([NULL], [NULL], [NULL]);) 2025.11.13 09:23:53.991063 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:54.095720 [ 16233 ] {75e6c6e5-90e4-4e19-b018-3f26829895f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 958, line 960) (in query: SELECT notEmpty([NULL], [NULL], [NULL]);) 2025.11.13 09:23:54.116404 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:54.191217 [ 16233 ] {168f4926-3e6b-4869-8858-f683498e72dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 959, line 961) (in query: SELECT notEquals([NULL], [NULL], [NULL]);) 2025.11.13 09:23:54.204035 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:54.312712 [ 16233 ] {847d694c-20f8-4fb7-a428-aa0cd0e76ddf} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 960, line 962) (in query: SELECT notILike([NULL], [NULL], [NULL]);) 2025.11.13 09:23:54.326166 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:54.394795 [ 16233 ] {d528207a-6c37-4268-a034-4df44861eb6b} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 961, line 963) (in query: SELECT notIn([NULL], [NULL], [NULL]);) 2025.11.13 09:23:54.400563 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 603.58 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:54.402932 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 603.58 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:54.409290 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:54.557667 [ 16233 ] {0f1a5721-0346-46a5-82a9-5c09d7619186} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 962, line 964) (in query: SELECT notInIgnoreSet([NULL], [NULL], [NULL]);) 2025.11.13 09:23:54.571811 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:54.700938 [ 16233 ] {b77ae18d-440f-4032-934c-ad1c373a5def} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 963, line 965) (in query: SELECT notLike([NULL], [NULL], [NULL]);) 2025.11.13 09:23:54.715007 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:54.774519 [ 16233 ] {6e0714a3-979d-4df4-a9f1-35f5c2518bc0} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 964, line 966) (in query: SELECT notNullIn([NULL], [NULL], [NULL]);) 2025.11.13 09:23:54.856033 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:54.980909 [ 16233 ] {608a585c-36be-4521-a5b1-a52211de7669} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 965, line 967) (in query: SELECT notNullInIgnoreSet([NULL], [NULL], [NULL]);) 2025.11.13 09:23:54.993658 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:55.539854 [ 16233 ] {ff3bb01b-57a1-405e-bd37-0c9f9e88a52e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=867). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 967, line 969) (in query: SELECT nothingNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:55.559060 [ 16233 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=867). (CANNOT_SCHEDULE_TASK) 2025.11.13 09:23:55.773001 [ 16233 ] {736ac4e7-096e-4b68-aa81-7c1ce2b250bb} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 969, line 971) (in query: SELECT now([NULL], [NULL], [NULL]);) 2025.11.13 09:23:55.786907 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:55.917369 [ 16233 ] {b48934a9-cc1b-458d-a42b-6d46d39f0ba3} executeQuery: Code: 34. DB::Exception: Arguments size of function now64 should be 0, or 1, or 2: In scope SELECT now64([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 970, line 972) (in query: SELECT now64([NULL], [NULL], [NULL]);) 2025.11.13 09:23:55.934989 [ 16233 ] {} TCPHandler: Code: 34. DB::Exception: Arguments size of function now64 should be 0, or 1, or 2: In scope SELECT now64([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.11.13 09:23:55.994272 [ 16233 ] {24cdab3a-4a9a-4c17-abd6-51e48727f729} executeQuery: Code: 34. DB::Exception: Arguments size of function nowInBlock should be 0 or 1: In scope SELECT nowInBlock([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 971, line 973) (in query: SELECT nowInBlock([NULL], [NULL], [NULL]);) 2025.11.13 09:23:56.007606 [ 16233 ] {} TCPHandler: Code: 34. DB::Exception: Arguments size of function nowInBlock should be 0 or 1: In scope SELECT nowInBlock([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.11.13 09:23:56.094301 [ 16233 ] {e03aad05-86de-4285-a3c4-101b7938b620} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 972, line 974) (in query: SELECT nth_value([NULL], [NULL], [NULL]);) 2025.11.13 09:23:56.108684 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:56.409032 [ 16233 ] {1318a04b-75ea-4e4c-bc3e-20aa2e1910b9} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 973, line 975) (in query: SELECT ntile([NULL], [NULL], [NULL]);) 2025.11.13 09:23:56.431293 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:56.496194 [ 16233 ] {9d990ee7-67bf-4586-a466-6375036588d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 974, line 976) (in query: SELECT nullIf([NULL], [NULL], [NULL]);) 2025.11.13 09:23:56.502481 [ 16693 ] {da138cde-c3bb-4765-b425-27eeee5ba97d} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 610.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37338) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: CREATE TABLE IF NOT EXISTS test_01516_test_1.data2 ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 13313, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 112, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 169350409, compact_parts_max_granules_to_buffer = 188, compact_parts_merge_max_bytes_to_prefetch_part = 66909, merge_max_block_size = 8184, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26983051, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 17, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 35540, primary_key_compress_block_size = 61589, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true AS SELECT * FROM numbers(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:23:56.513221 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:56.605808 [ 16233 ] {2fc004cd-18b9-412c-bc1f-371833995a3e} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 975, line 977) (in query: SELECT nullIn([NULL], [NULL], [NULL]);) 2025.11.13 09:23:56.607979 [ 16693 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 610.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:23:56.619859 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:56.680836 [ 16233 ] {bb9db8f6-fa0c-4fc5-959c-f7b1b5a56fcd} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 976, line 978) (in query: SELECT nullInIgnoreSet([NULL], [NULL], [NULL]);) 2025.11.13 09:23:56.695506 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:56.757521 [ 16233 ] {927819b6-43cc-487c-af7d-259c32d3b8a3} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function or: In scope SELECT [NULL] OR [NULL] OR [NULL]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 977, line 979) (in query: SELECT or([NULL], [NULL], [NULL]);) 2025.11.13 09:23:56.764473 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 616.64 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:56.766834 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 616.64 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:56.771927 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function or: In scope SELECT [NULL] OR [NULL] OR [NULL]. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:56.903160 [ 16233 ] {5c0e3962-cd47-4213-9737-518f1a9d8b98} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'overlay'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT overlay([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 978, line 980) (in query: SELECT overlay([NULL], [NULL], [NULL]);) 2025.11.13 09:23:56.956340 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'overlay'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT overlay([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:57.022527 [ 16233 ] {6530a0c7-405f-40f5-be38-a66e2861816e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'overlayUTF8'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT overlayUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 979, line 981) (in query: SELECT overlayUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:23:57.078720 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'overlayUTF8'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT overlayUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:57.138078 [ 16233 ] {ccf7274e-0928-4e37-9b4f-75ea2e7466e1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 980, line 982) (in query: SELECT parseDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:23:57.150497 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:57.244539 [ 16233 ] {5ae04dfa-823d-4417-abd7-5f18abdce76a} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 981, line 983) (in query: SELECT parseDateTime32BestEffort([NULL], [NULL], [NULL]);) 2025.11.13 09:23:57.257560 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:57.295857 [ 16215 ] {3d2837b9-91b3-4ee8-9aa5-8d391684244d} executeQuery: Code: 69. DB::Exception: A call to function range would produce 12 array elements, which is greater than the allowed maximum of 10: while executing 'FUNCTION range(modulo(__table1.number, 3_UInt8) :: 0) -> range(modulo(__table1.number, 3_UInt8)) Array(UInt8) : 1'. (ARGUMENT_OUT_OF_BOUND) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37310) (comment: 01944_range_max_elements.sql) (query 4, line 4) (in query: SELECT range(number % 3) FROM numbers(12);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. COW::immutable_ptr DB::FunctionRange::executeInternal(DB::IColumn const*) const @ 0x000000001f55fc54 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f554c4b 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:23:57.309492 [ 16215 ] {} TCPHandler: Code: 69. DB::Exception: A call to function range would produce 12 array elements, which is greater than the allowed maximum of 10: while executing 'FUNCTION range(modulo(__table1.number, 3_UInt8) :: 0) -> range(modulo(__table1.number, 3_UInt8)) Array(UInt8) : 1'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. COW::immutable_ptr DB::FunctionRange::executeInternal(DB::IColumn const*) const @ 0x000000001f55fc54 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f554c4b 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:23:57.323178 [ 16233 ] {412a462a-511c-4ddf-867c-dcb023d166fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 982, line 984) (in query: SELECT parseDateTime32BestEffortOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:57.337531 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:57.473211 [ 16233 ] {04444be4-720f-4d54-9e6f-6a151e636e6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 983, line 985) (in query: SELECT parseDateTime32BestEffortOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:23:57.485567 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:57.541424 [ 16233 ] {96e3031f-9dd1-4504-b364-37b5ea2863b0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 984, line 986) (in query: SELECT parseDateTime64([NULL], [NULL], [NULL]);) 2025.11.13 09:23:57.554732 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:57.633908 [ 16233 ] {6c18acf8-4089-418d-b527-3b3ee5f82554} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 985, line 987) (in query: SELECT parseDateTime64BestEffort([NULL], [NULL], [NULL]);) 2025.11.13 09:23:57.724797 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:57.820131 [ 16233 ] {f2d42f63-700f-4d99-81e8-dd65447d8642} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 986, line 988) (in query: SELECT parseDateTime64BestEffortOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:57.845740 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:57.917874 [ 16233 ] {704e5be8-df29-4432-9d70-82a407a08546} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 987, line 989) (in query: SELECT parseDateTime64BestEffortOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:23:57.931095 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:58.044204 [ 16233 ] {070cf675-f884-4336-902e-f7f4c0f51bc6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUS([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 988, line 990) (in query: SELECT parseDateTime64BestEffortUS([NULL], [NULL], [NULL]);) 2025.11.13 09:23:58.056471 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUS([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:58.223178 [ 16233 ] {748d8112-6cbb-4bd4-b1b9-9ef93a781289} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUSOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 989, line 991) (in query: SELECT parseDateTime64BestEffortUSOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:58.235446 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUSOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:58.337920 [ 16233 ] {c60e2a6a-4c31-4710-88f4-fca94c9c02b3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUSOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 990, line 992) (in query: SELECT parseDateTime64BestEffortUSOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:23:58.354456 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUSOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:58.525147 [ 16233 ] {27013a33-1f43-43f0-9ed2-e0fda1b6e33f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntax'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64InJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 991, line 993) (in query: SELECT parseDateTime64InJodaSyntax([NULL], [NULL], [NULL]);) 2025.11.13 09:23:58.541518 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntax'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64InJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:58.606466 [ 16233 ] {02041952-687f-4ad0-a75d-49d4063d990d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64InJodaSyntaxOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 992, line 994) (in query: SELECT parseDateTime64InJodaSyntaxOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:58.626181 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64InJodaSyntaxOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:58.688278 [ 16233 ] {29442645-9f6a-4923-a76e-3a4731cdf8dc} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64InJodaSyntaxOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 993, line 995) (in query: SELECT parseDateTime64InJodaSyntaxOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:23:58.787819 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64InJodaSyntaxOrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64InJodaSyntaxOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:58.852278 [ 16233 ] {7af49169-fcb2-4c1f-9952-9cfd37d9dcec} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64OrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 994, line 996) (in query: SELECT parseDateTime64OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:58.870236 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64OrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:58.974958 [ 16233 ] {30e78fe1-29de-46ab-a23a-e826e8a60c2f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64OrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 995, line 997) (in query: SELECT parseDateTime64OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:23:58.988250 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime64OrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64OrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:59.050843 [ 16233 ] {94461c4c-10ee-4df5-90bd-1faf041f851a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffort'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 996, line 998) (in query: SELECT parseDateTimeBestEffort([NULL], [NULL], [NULL]);) 2025.11.13 09:23:59.064739 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffort'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:59.111055 [ 3726 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_128_10} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 547.76 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:59.113664 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_128_10}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 547.76 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:59.123715 [ 16233 ] {66b3d246-6264-450c-b0a4-1b874ebaa492} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffortOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 997, line 999) (in query: SELECT parseDateTimeBestEffortOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:59.140945 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffortOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:59.318423 [ 16233 ] {db10c348-41f4-40f5-a6f8-638401bdbce4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffortOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 998, line 1000) (in query: SELECT parseDateTimeBestEffortOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:23:59.355980 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffortOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:23:59.464508 [ 16233 ] {0e145b16-0a7a-4bff-8c9a-18ab840f8fc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 999, line 1001) (in query: SELECT parseDateTimeBestEffortUS([NULL], [NULL], [NULL]);) 2025.11.13 09:23:59.477410 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:59.585153 [ 16233 ] {54bb28b1-0ec8-47b5-b62f-e89c4fc6bc61} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1000, line 1002) (in query: SELECT parseDateTimeBestEffortUSOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:23:59.597022 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:59.733781 [ 16233 ] {19d378f7-a074-4105-a530-a98a0a581174} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1001, line 1003) (in query: SELECT parseDateTimeBestEffortUSOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:23:59.736767 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 627.58 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:59.738850 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 627.58 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:23:59.747098 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:23:59.892335 [ 16233 ] {fe7c701f-9cc8-4847-801d-20410c5b93b2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1002, line 1004) (in query: SELECT parseDateTimeInJodaSyntax([NULL], [NULL], [NULL]);) 2025.11.13 09:23:59.904515 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:00.058350 [ 16233 ] {f78bb4d7-d943-46fe-bcde-9266cd38f86a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntaxOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1003, line 1005) (in query: SELECT parseDateTimeInJodaSyntaxOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:00.134844 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntaxOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:00.224939 [ 16233 ] {452524ab-0c40-4baf-84be-dc25d9a785a6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntaxOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1004, line 1006) (in query: SELECT parseDateTimeInJodaSyntaxOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:00.249323 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntaxOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:00.464057 [ 16233 ] {cd7390f9-c946-4ee5-8d79-b2d27c22cb0f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1005, line 1007) (in query: SELECT parseDateTimeOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:00.478714 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:00.586447 [ 6078 ] {8fe556b7-84ee-4a0f-acb1-e11c8664cec4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43744) (comment: 00094_union_race_conditions_5.sh) (query 53, line 53) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:24:00.591712 [ 16233 ] {54dc452b-4875-48d6-babb-4b5d80538cad} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1006, line 1008) (in query: SELECT parseDateTimeOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:00.602959 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:00.603045 [ 6078 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:24:00.663849 [ 16233 ] {b3650f7f-ff58-498c-baf9-9635285323a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1007, line 1009) (in query: SELECT parseReadableSize([NULL], [NULL], [NULL]);) 2025.11.13 09:24:00.676146 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:00.847292 [ 16233 ] {362db2b6-ec78-41ab-9b98-609a04e18b90} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1008, line 1010) (in query: SELECT parseReadableSizeOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:00.860774 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:01.066374 [ 16233 ] {f0aeaab1-1bc9-4326-90cb-0d60abe9573b} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1009, line 1011) (in query: SELECT parseReadableSizeOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:01.081503 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:01.147740 [ 16233 ] {e2784155-ed9d-4812-91c2-595e83445eff} executeQuery: Code: 34. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 3, should be 1.: In scope SELECT parseTimeDelta([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1010, line 1012) (in query: SELECT parseTimeDelta([NULL], [NULL], [NULL]);) 2025.11.13 09:24:01.161595 [ 16233 ] {} TCPHandler: Code: 34. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 3, should be 1.: In scope SELECT parseTimeDelta([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.11.13 09:24:01.462969 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 582.25 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:01.465751 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 582.25 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:01.487361 [ 16233 ] {e7797329-76a0-4613-929b-9a427b7c7203} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1013, line 1015) (in query: SELECT path([NULL], [NULL], [NULL]);) 2025.11.13 09:24:01.499930 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:01.586878 [ 16233 ] {03331e00-d702-4674-b49d-041c5053cfe4} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1014, line 1016) (in query: SELECT pathFull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:01.599121 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:01.618672 [ 19171 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:24:01.619793 [ 19171 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:24:01.832101 [ 16233 ] {160993b6-3b44-4e36-bf50-8da49c34e28e} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1015, line 1017) (in query: SELECT percentRank([NULL], [NULL], [NULL]);) 2025.11.13 09:24:01.851144 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:24:02.046989 [ 16233 ] {e3261d6e-cc43-460e-9a15-bb9c7b5b9be1} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1016, line 1018) (in query: SELECT percent_rank([NULL], [NULL], [NULL]);) 2025.11.13 09:24:02.071415 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:24:02.132433 [ 16233 ] {36c4b0cb-241e-43f5-86a8-17c1199b391f} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1017, line 1019) (in query: SELECT pi([NULL], [NULL], [NULL]);) 2025.11.13 09:24:02.144587 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:02.253934 [ 16233 ] {955ef09f-7d91-4f91-8126-21bc6b304d14} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1018, line 1020) (in query: SELECT plus([NULL], [NULL], [NULL]);) 2025.11.13 09:24:02.268384 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:02.351371 [ 16233 ] {16f8291b-08ce-4393-afe4-9e07d3500aa7} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1019, line 1021) (in query: SELECT pmod([NULL], [NULL], [NULL]);) 2025.11.13 09:24:02.364147 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:02.420587 [ 16233 ] {bce27dba-f60d-4395-8b5a-9f11704863aa} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1020, line 1022) (in query: SELECT pointInEllipses([NULL], [NULL], [NULL]);) 2025.11.13 09:24:02.433716 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:02.464488 [ 16186 ] {9a230744-f1c4-45a4-a477-f0b96ee5ed03} executeQuery: Code: 60. DB::Exception: Table test_9zebc78i.t_json_16 does not exist. Maybe you meant test_13.t_json?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59606) (comment: 01825_type_json_16.sh) (query 1, line 1) (in query: INSERT INTO t_json_16 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:24:02.479557 [ 16186 ] {} TCPHandler: Code: 60. DB::Exception: Table test_9zebc78i.t_json_16 does not exist. Maybe you meant test_13.t_json?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:24:02.494073 [ 16233 ] {58c30446-acf8-49ed-9185-e69cc1381b42} executeQuery: Code: 43. DB::Exception: Argument 1 for function pointInPolygon must contain a tuple: In scope SELECT pointInPolygon([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1021, line 1023) (in query: SELECT pointInPolygon([NULL], [NULL], [NULL]);) 2025.11.13 09:24:02.608314 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Argument 1 for function pointInPolygon must contain a tuple: In scope SELECT pointInPolygon([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:02.721737 [ 16233 ] {c807e5c2-d9cb-47db-b397-476b56740e7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1022, line 1024) (in query: SELECT polygonAreaCartesian([NULL], [NULL], [NULL]);) 2025.11.13 09:24:02.734786 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:02.792971 [ 16233 ] {2f9d3b0a-3dfc-4bb6-a059-92b34d1b37f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1023, line 1025) (in query: SELECT polygonAreaSpherical([NULL], [NULL], [NULL]);) 2025.11.13 09:24:02.805096 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:02.865359 [ 16233 ] {15592173-f8b2-4cda-b39b-ac2f089f8fe6} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1024, line 1026) (in query: SELECT polygonConvexHullCartesian([NULL], [NULL], [NULL]);) 2025.11.13 09:24:02.878061 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:02.946197 [ 16233 ] {f191bcd5-ddb0-41dd-a6bf-a69fbdcb8e2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1025, line 1027) (in query: SELECT polygonPerimeterCartesian([NULL], [NULL], [NULL]);) 2025.11.13 09:24:02.959489 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:03.015503 [ 16233 ] {dcc3f130-4c64-4c16-a920-4713caf76432} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1026, line 1028) (in query: SELECT polygonPerimeterSpherical([NULL], [NULL], [NULL]);) 2025.11.13 09:24:03.028985 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:03.079848 [ 16215 ] {964707ea-3f81-4430-9fb6-bc830a5c6486} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59578) (comment: 00094_union_race_conditions_5.sh) (query 6, line 6) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:24:03.091664 [ 16233 ] {38711778-1ccb-4979-ac43-fde49cb3fc7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1027, line 1029) (in query: SELECT polygonsDistanceCartesian([NULL], [NULL], [NULL]);) 2025.11.13 09:24:03.098842 [ 16215 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:24:03.105949 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:03.267047 [ 16233 ] {6deb05ab-bc37-46f3-bb05-2e35d2a059af} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1028, line 1030) (in query: SELECT polygonsDistanceSpherical([NULL], [NULL], [NULL]);) 2025.11.13 09:24:03.416161 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:03.471981 [ 16233 ] {519412b1-346c-4c96-a3ca-33c93f828145} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1029, line 1031) (in query: SELECT polygonsEqualsCartesian([NULL], [NULL], [NULL]);) 2025.11.13 09:24:03.523727 [ 16186 ] {a79dc928-0d08-4219-b8ba-d604a8d9ef25} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_16. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59636) (comment: 01825_type_json_16.sh) (query 1, line 1) (in query: SELECT DISTINCT toTypeName(obj) FROM t_json_16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:03.537559 [ 16186 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_16. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:03.642052 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:03.701334 [ 16233 ] {1f5acd50-7d11-4b8c-b79f-f7c0fe20f10b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1030, line 1032) (in query: SELECT polygonsIntersectionCartesian([NULL], [NULL], [NULL]);) 2025.11.13 09:24:03.724555 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:03.734740 [ 18149 ] {d693e5f7-a02b-4f89-9acf-35e228748e2e} executeQuery: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59562) (comment: 01710_projections.sql) (query 5, line 9) (in query: select * from projection_test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c563c 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:24:03.744951 [ 18149 ] {} TCPHandler: Code: 584. DB::Exception: No projection is used when optimize_use_projections = 1 and force_optimize_projection = 1. (PROJECTION_NOT_USED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:242: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c563c 5. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 6. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 7. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:24:03.856769 [ 16233 ] {5815729f-512e-4c3c-a929-d8f79701bb2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1031, line 1033) (in query: SELECT polygonsIntersectionSpherical([NULL], [NULL], [NULL]);) 2025.11.13 09:24:03.871203 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:03.905459 [ 16215 ] {3db84699-39ad-40c5-82fe-1607ef0e9669} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function UUIDStringToNum must be constant. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59620) (comment: 03095_msan_uuid_string_to_num.sql) (query 2, line 2) (in query: SELECT UUIDStringToNum('00112233-4455-6677-8899-aabbccddeeff', materialize(2));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14508e 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 13. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:03.913407 [ 16215 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function UUIDStringToNum must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14508e 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 13. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:03.940542 [ 16233 ] {de055c68-ea7c-4e7d-baab-8246d1f117bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1032, line 1034) (in query: SELECT polygonsSymDifferenceCartesian([NULL], [NULL], [NULL]);) 2025.11.13 09:24:03.958239 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:04.035871 [ 16233 ] {55fcff8b-ea4b-4f12-8d42-ede113e47ede} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1033, line 1035) (in query: SELECT polygonsSymDifferenceSpherical([NULL], [NULL], [NULL]);) 2025.11.13 09:24:04.050676 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:04.112138 [ 16233 ] {6ab9ab77-23b4-4dd4-811f-bf2f3bdb71e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1034, line 1036) (in query: SELECT polygonsUnionCartesian([NULL], [NULL], [NULL]);) 2025.11.13 09:24:04.119826 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 535.26 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:04.121882 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 535.26 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:04.124517 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:04.183184 [ 16233 ] {f7d80eef-0dc5-41b9-b2ed-20bdefdf17c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1035, line 1037) (in query: SELECT polygonsUnionSpherical([NULL], [NULL], [NULL]);) 2025.11.13 09:24:04.197135 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:04.259777 [ 16233 ] {964fa890-7a9f-412b-87d9-6e20cfd0f06b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1036, line 1038) (in query: SELECT polygonsWithinCartesian([NULL], [NULL], [NULL]);) 2025.11.13 09:24:04.273365 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:04.339924 [ 16233 ] {323fb280-f035-4a41-8602-8b101c13040e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1037, line 1039) (in query: SELECT polygonsWithinSpherical([NULL], [NULL], [NULL]);) 2025.11.13 09:24:04.358371 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:04.392662 [ 16215 ] {d9f2de9e-cc61-4107-8aab-77374b2270f4} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function UUIDNumToString must be constant. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59620) (comment: 03095_msan_uuid_string_to_num.sql) (query 4, line 4) (in query: SELECT 'a/<@];!~p{jTj={)' AS bytes, UUIDNumToString(toFixedString(bytes, 16), materialize(2)) AS uuid;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14508e 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 13. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:04.400735 [ 16215 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function UUIDNumToString must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14508e 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 13. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:04.487221 [ 16233 ] {7a7131f4-2463-4aa2-abb2-1c1f169a07d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 3, should be 1 or 2: In scope SELECT port([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1038, line 1040) (in query: SELECT port([NULL], [NULL], [NULL]);) 2025.11.13 09:24:04.500758 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 3, should be 1 or 2: In scope SELECT port([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:04.563815 [ 16233 ] {e1ee3bca-b5ab-4ba1-84be-7017a28c528e} executeQuery: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 3, should be 1 or 2: In scope SELECT portRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1039, line 1041) (in query: SELECT portRFC([NULL], [NULL], [NULL]);) 2025.11.13 09:24:04.581524 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 3, should be 1 or 2: In scope SELECT portRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:04.631637 [ 16215 ] {f39daa47-fc78-4c7d-b2b9-8ae4a37d96a3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59672) (comment: 01825_type_json_16.sh) (query 1, line 1) (in query: SELECT obj FROM t_json_16 ORDER BY obj.id FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:04.645072 [ 16215 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:04.702511 [ 16889 ] {3784f650-00ab-4f4a-953d-31a143bed347} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:44704) (comment: 02024_join_on_or_long.gen.sql) (in query: DROP DATABASE IF EXISTS test_69caz0xx SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:24:04.711350 [ 16889 ] {3784f650-00ab-4f4a-953d-31a143bed347} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:04.712804 [ 16233 ] {5c7f3fce-82e7-47b1-931a-7b8c92c08fbc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function position: In scope SELECT position([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1040, line 1042) (in query: SELECT position([NULL], [NULL], [NULL]);) 2025.11.13 09:24:04.728092 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function position: In scope SELECT position([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:04.757197 [ 18700 ] {ccb361aa-1b26-4ae2-968b-5f80fb429aec} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:53198) (comment: 02024_join_on_or_long.gen.sql) (in query: DROP DATABASE IF EXISTS test_69caz0xx SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:24:04.777426 [ 18700 ] {ccb361aa-1b26-4ae2-968b-5f80fb429aec} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:04.803660 [ 16233 ] {5b7aab64-b313-4429-a096-89360bdb38e8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitive: In scope SELECT positionCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1041, line 1043) (in query: SELECT positionCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:24:04.817767 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitive: In scope SELECT positionCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:04.906780 [ 18149 ] {9d52b313-46c0-4c05-b476-619865e4ef25} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59562) (comment: 01710_projections.sql) (query 6, line 10) (in query: select toStartOfMinute(datetime) dt_m, countIf(first_time = 0) from projection_test join (select 1) x on 1 where domain = '1' group by dt_m order by dt_m;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1262: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cecc4f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1409: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c86c7c 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x0000000032bddb86 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bddfe8 12. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:717: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000003703f83e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1063: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c6a069 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:24:04.920293 [ 18149 ] {} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoins.cpp:1262: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cecc4f 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1409: DB::(anonymous namespace)::buildJoinQueryPlan(DB::QueryPlan, DB::QueryPlan, std::shared_ptr&, DB::JoinClausesAndActions&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c86c7c 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1948: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c7bfa3 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 8. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 9. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:236: DB::InterpreterSelectQueryAnalyzer::getSampleBlockAndPlannerContext() @ 0x0000000032bddb86 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:218: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bddfe8 12. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:717: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000003703f83e 13. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1063: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c6a069 14. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 15. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:24:04.930884 [ 16233 ] {1afbccc5-dfc5-4172-83b5-35ee2b62b275} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitiveUTF8: In scope SELECT positionCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1042, line 1044) (in query: SELECT positionCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:04.943269 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitiveUTF8: In scope SELECT positionCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:05.001281 [ 16233 ] {c0e6b079-f912-4c2d-8066-617c7897f530} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionUTF8: In scope SELECT positionUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1043, line 1045) (in query: SELECT positionUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:05.017994 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionUTF8: In scope SELECT positionUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:05.070556 [ 16233 ] {bb648c68-f0bf-47e0-bef1-f1518839738a} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1044, line 1046) (in query: SELECT positiveModulo([NULL], [NULL], [NULL]);) 2025.11.13 09:24:05.156327 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:05.240635 [ 16233 ] {3673229f-758a-4235-b325-9056d4aa2142} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1045, line 1047) (in query: SELECT positive_modulo([NULL], [NULL], [NULL]);) 2025.11.13 09:24:05.258080 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:05.308109 [ 16233 ] {1faa88f3-3f40-4796-ba18-cf0cfbcf4b01} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1046, line 1048) (in query: SELECT pow([NULL], [NULL], [NULL]);) 2025.11.13 09:24:05.320303 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:05.371941 [ 16233 ] {984183c9-19dd-4f75-a645-b7d2e16ddd07} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1047, line 1049) (in query: SELECT power([NULL], [NULL], [NULL]);) 2025.11.13 09:24:05.383498 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:05.589409 [ 16233 ] {5f7a266f-9325-4d49-abe3-90fc0a807a52} executeQuery: Code: 43. DB::Exception: The first argument type of function printf is Array(Nullable(Nothing)), but String type is expected: In scope SELECT printf([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1048, line 1050) (in query: SELECT printf([NULL], [NULL], [NULL]);) 2025.11.13 09:24:05.602931 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: The first argument type of function printf is Array(Nullable(Nothing)), but String type is expected: In scope SELECT printf([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:05.721654 [ 16233 ] {3f189137-8210-45a6-ba51-6cd35f0a5068} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1049, line 1051) (in query: SELECT proportionsZTest([NULL], [NULL], [NULL]);) 2025.11.13 09:24:05.723716 [ 18700 ] {72913030-8dc1-4fce-b8ca-1c0d274189de} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj.key_0.key_1.key_2.key_3.key_4, obj.key_0.key_1.key_2.key_3.key_6, obj.key_0.key_1.key_2.key_3.key_7, obj.key_0.key_1.key_2.key_5.key_6, obj.key_0.key_1.key_2.key_5.key_7 FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59722) (comment: 01825_type_json_16.sh) (query 1, line 1) (in query: SELECT obj.key_0.key_1.key_2.key_3.key_4, obj.key_0.key_1.key_2.key_3.key_6, obj.key_0.key_1.key_2.key_3.key_7, obj.key_0.key_1.key_2.key_5.key_6, obj.key_0.key_1.key_2.key_5.key_7 FROM t_json_16 ORDER BY obj.id), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:05.733656 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:05.772303 [ 16344 ] {f300cb61-8394-491a-8405-defc542a317d} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 522.40 MiB (attempt to allocate chunk of 1.59 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column order_0): (while reading from part /var/lib/clickhouse/store/b17/b17e21cf-afd1-4249-8ff4-d09cb2ec3b1b/198401_1_1_0/ in table test_9upxx8dd.t_reverse_order_virt_col (b17e21cf-afd1-4249-8ff4-d09cb2ec3b1b) located on disk default of type local, from mark 187 with max_rows_to_read = 26862): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37454) (comment: 02883_read_in_reverse_order_virtual_column.sql) (query 4, line 8) (in query: SELECT DISTINCT _part FROM (SELECT _part FROM t_reverse_order_virt_col ORDER BY order_0 DESC);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<32ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000a3ff76c 12. ./build_docker/./src/DataTypes/Serializations/SerializationDecimalBase.cpp:62: DB::SerializationDecimalBase>>::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f5f39ff 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:297: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7aca4d 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 2025.11.13 09:24:05.788971 [ 16233 ] {3c56326b-7764-4b97-af90-6cdddc99ab84} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1050, line 1052) (in query: SELECT protocol([NULL], [NULL], [NULL]);) 2025.11.13 09:24:05.802306 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:05.809760 [ 18700 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj.key_0.key_1.key_2.key_3.key_4, obj.key_0.key_1.key_2.key_3.key_6, obj.key_0.key_1.key_2.key_3.key_7, obj.key_0.key_1.key_2.key_5.key_6, obj.key_0.key_1.key_2.key_5.key_7 FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:05.856448 [ 16344 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 522.40 MiB (attempt to allocate chunk of 1.59 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column order_0): (while reading from part /var/lib/clickhouse/store/b17/b17e21cf-afd1-4249-8ff4-d09cb2ec3b1b/198401_1_1_0/ in table test_9upxx8dd.t_reverse_order_virt_col (b17e21cf-afd1-4249-8ff4-d09cb2ec3b1b) located on disk default of type local, from mark 187 with max_rows_to_read = 26862): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<32ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000a3ff76c 12. ./build_docker/./src/DataTypes/Serializations/SerializationDecimalBase.cpp:62: DB::SerializationDecimalBase>>::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f5f39ff 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:297: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7aca4d 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 21. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:24:05.922528 [ 16233 ] {642673e9-2c95-4b33-8ea0-e5bdfb2bf970} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1051, line 1053) (in query: SELECT punycodeDecode([NULL], [NULL], [NULL]);) 2025.11.13 09:24:05.936885 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:06.043855 [ 16233 ] {cad1b435-07f6-49ac-a38a-8a80b57e68c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1052, line 1054) (in query: SELECT punycodeEncode([NULL], [NULL], [NULL]);) 2025.11.13 09:24:06.061096 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:06.120412 [ 16233 ] {cd211f2c-f7a4-4078-b8d8-68578f1c7f95} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1053, line 1055) (in query: SELECT quantile([NULL], [NULL], [NULL]);) 2025.11.13 09:24:06.134813 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:06.190447 [ 16233 ] {9b02f334-b280-45a5-a564-1f637c1e7eaa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1054, line 1056) (in query: SELECT quantileBFloat16([NULL], [NULL], [NULL]);) 2025.11.13 09:24:06.203429 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:06.259666 [ 16233 ] {60cc9630-7051-4541-ab79-dfcc50a00ea2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1055, line 1057) (in query: SELECT quantileBFloat16Weighted([NULL], [NULL], [NULL]);) 2025.11.13 09:24:06.273038 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:06.422424 [ 16233 ] {e16bfff9-8765-4ec1-bda8-ee4f7fdcde12} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1056, line 1058) (in query: SELECT quantileDD([NULL], [NULL], [NULL]);) 2025.11.13 09:24:06.464728 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:06.603845 [ 16233 ] {6023ac38-d32c-498c-aa29-13860c1f38b1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1057, line 1059) (in query: SELECT quantileDeterministic([NULL], [NULL], [NULL]);) 2025.11.13 09:24:06.624589 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:06.679014 [ 16233 ] {e777d726-eacc-4ec1-ac61-689bbdfa7e3f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1058, line 1060) (in query: SELECT quantileExact([NULL], [NULL], [NULL]);) 2025.11.13 09:24:06.694475 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:06.911874 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 579.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:06.914253 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 579.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:06.947932 [ 16233 ] {828e0a41-a3cb-4ff6-bf3f-6632333e0d1d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1059, line 1061) (in query: SELECT quantileExactExclusive([NULL], [NULL], [NULL]);) 2025.11.13 09:24:06.965847 [ 16344 ] {9065ec81-6d6f-40df-8bd3-dfa5bff29178} executeQuery: Code: 60. DB::Exception: Table test_9zebc78i.t_json_16 does not exist. Maybe you meant test_13.t_json?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59770) (comment: 01825_type_json_16.sh) (query 1, line 1) (in query: DROP TABLE t_json_16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:06.974192 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:07.048664 [ 16233 ] {fad23ef0-efb9-4793-afda-3eee08b92baf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1060, line 1062) (in query: SELECT quantileExactHigh([NULL], [NULL], [NULL]);) 2025.11.13 09:24:07.055515 [ 16344 ] {} TCPHandler: Code: 60. DB::Exception: Table test_9zebc78i.t_json_16 does not exist. Maybe you meant test_13.t_json?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:07.067492 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:07.128534 [ 16233 ] {f5737ff5-18e0-4475-9f85-dfb47776ce7d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1061, line 1063) (in query: SELECT quantileExactInclusive([NULL], [NULL], [NULL]);) 2025.11.13 09:24:07.140578 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:07.211260 [ 16233 ] {d9705aba-1c49-4825-819e-346fcd7d7ff2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1062, line 1064) (in query: SELECT quantileExactLow([NULL], [NULL], [NULL]);) 2025.11.13 09:24:07.224332 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:07.369670 [ 16233 ] {910ac08a-224b-4f7c-a1c7-ab0f3d0aad96} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1063, line 1065) (in query: SELECT quantileExactWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:24:07.384989 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:07.442827 [ 16233 ] {82a2c743-e370-4423-8c14-8003d10cc714} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1064, line 1066) (in query: SELECT quantileExactWeightedInterpolated([NULL], [NULL], [NULL]);) 2025.11.13 09:24:07.456018 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:07.514292 [ 16233 ] {b0c1652b-24cd-4f15-a81a-ce2f460cb6b8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1065, line 1067) (in query: SELECT quantileGK([NULL], [NULL], [NULL]);) 2025.11.13 09:24:07.528831 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:07.673466 [ 16233 ] {d81c42f5-54a8-482f-bf6c-3e834519554b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1066, line 1068) (in query: SELECT quantileInterpolatedWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:24:07.687245 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:07.718481 [ 16215 ] {} DynamicQueryHandler: Code: 744. DB::Exception: Session id query parameter was provided, but it was empty. (SESSION_ID_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/HTTPHandler.cpp:244: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003ace1657 5. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 6. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:07.769951 [ 16233 ] {073d844a-9f18-43f0-94da-04cc584af6a6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1067, line 1069) (in query: SELECT quantileTDigest([NULL], [NULL], [NULL]);) 2025.11.13 09:24:07.783560 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:07.948226 [ 16233 ] {9c723513-7fa3-4e29-bccd-40165daa8d14} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1068, line 1070) (in query: SELECT quantileTDigestWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:24:07.961169 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:08.015657 [ 16233 ] {e6ec56b2-8024-47be-84e9-ddd7dcfef9a7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1069, line 1071) (in query: SELECT quantileTiming([NULL], [NULL], [NULL]);) 2025.11.13 09:24:08.052667 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:08.125190 [ 16233 ] {0c3fedb1-f2a6-4ce3-8f09-f03ecdf53aab} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1070, line 1072) (in query: SELECT quantileTimingWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:24:08.136987 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:08.190408 [ 16233 ] {b21705bf-1883-46c8-b261-d6144c9de969} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1071, line 1073) (in query: SELECT quantiles([NULL], [NULL], [NULL]);) 2025.11.13 09:24:08.285135 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:08.340004 [ 16233 ] {358d1e4f-65f8-492c-940d-87a0efec9af8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1072, line 1074) (in query: SELECT quantilesBFloat16([NULL], [NULL], [NULL]);) 2025.11.13 09:24:08.378748 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:08.488150 [ 16233 ] {aee34dff-7037-4095-9251-28ed6028bf19} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1073, line 1075) (in query: SELECT quantilesBFloat16Weighted([NULL], [NULL], [NULL]);) 2025.11.13 09:24:08.593103 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:08.598710 [ 18149 ] {9783b0b3-9c3b-41a2-92c7-38cf8c3bc7fe} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 4, line 6) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree ORDER BY d SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:08.606566 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:08.673342 [ 16233 ] {750c7553-9aca-4a72-b3dd-2f0566a34b22} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1074, line 1076) (in query: SELECT quantilesDD([NULL], [NULL], [NULL]);) 2025.11.13 09:24:08.674396 [ 18149 ] {f3154f3c-4472-42a7-8d67-ba91df5cfa1a} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 5, line 7) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree ORDER BY tuple(d) SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:08.696162 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:08.779218 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:08.837762 [ 16233 ] {1f79a164-cd21-4793-a19c-0dc83d64ee3a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1075, line 1077) (in query: SELECT quantilesDeterministic([NULL], [NULL], [NULL]);) 2025.11.13 09:24:08.929344 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:09.031328 [ 16233 ] {0aaedb81-5445-417d-9702-6f91bdedf06d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1076, line 1078) (in query: SELECT quantilesExact([NULL], [NULL], [NULL]);) 2025.11.13 09:24:09.044572 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:09.101962 [ 16233 ] {07fdaa24-6d17-467e-8388-b1a6a66b3d96} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1077, line 1079) (in query: SELECT quantilesExactExclusive([NULL], [NULL], [NULL]);) 2025.11.13 09:24:09.115451 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:09.176254 [ 16233 ] {ace8e879-7098-46c4-b126-c0b897087757} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1078, line 1080) (in query: SELECT quantilesExactHigh([NULL], [NULL], [NULL]);) 2025.11.13 09:24:09.189584 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:09.253333 [ 16233 ] {b2e4a652-9ec2-4f90-aaac-b0b1c0d46b1c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1079, line 1081) (in query: SELECT quantilesExactInclusive([NULL], [NULL], [NULL]);) 2025.11.13 09:24:09.353018 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:09.495657 [ 16233 ] {235cb7a4-826a-45d5-80d6-1607d06d8231} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1080, line 1082) (in query: SELECT quantilesExactLow([NULL], [NULL], [NULL]);) 2025.11.13 09:24:09.515400 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:09.643850 [ 18149 ] {2a82acae-2594-48df-80c1-fed0d26c995e} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 6, line 8) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree ORDER BY [d] SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:24:09.654617 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:24:09.767257 [ 16233 ] {b8f41d44-e671-448d-9f61-7aa317792866} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1081, line 1083) (in query: SELECT quantilesExactWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:24:09.782258 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:10.027940 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 604.35 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6bfcf6 24. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7e7388 25. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 26. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:429: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6b672a 27. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 28. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 31. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:10.030582 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 604.35 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6bfcf6 24. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7e7388 25. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 26. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:429: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6b672a 27. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 28. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 31. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:10.040393 [ 16233 ] {1cd5fe0a-4cd6-46fa-8721-aad5612493b3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1082, line 1084) (in query: SELECT quantilesExactWeightedInterpolated([NULL], [NULL], [NULL]);) 2025.11.13 09:24:10.056827 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactWeightedInterpolated. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:10.121078 [ 16233 ] {68bd6cf9-d239-4d3e-b361-61b639d6d129} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1083, line 1085) (in query: SELECT quantilesGK([NULL], [NULL], [NULL]);) 2025.11.13 09:24:10.135908 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:10.218878 [ 16233 ] {04b38ab4-18df-4df7-ad1c-460ed68410ae} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1084, line 1086) (in query: SELECT quantilesInterpolatedWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:24:10.241392 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:10.391985 [ 16233 ] {011cebe1-5d82-4bd3-860e-d0a3933e75aa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1085, line 1087) (in query: SELECT quantilesTDigest([NULL], [NULL], [NULL]);) 2025.11.13 09:24:10.493530 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:10.558909 [ 16233 ] {31dd52c0-de56-4575-9592-30d5bdb826c3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1086, line 1088) (in query: SELECT quantilesTDigestWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:24:10.574823 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:10.662618 [ 18149 ] {ffad1980-3fee-4380-9336-78cb9731f427} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 7, line 9) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree ORDER BY map('str', d) SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:24:10.681607 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:24:10.740247 [ 16233 ] {2b7b28fb-e9c0-4b32-a014-6a8a6cb80d52} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1087, line 1089) (in query: SELECT quantilesTiming([NULL], [NULL], [NULL]);) 2025.11.13 09:24:10.759334 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:10.907404 [ 16233 ] {7c89a8ce-448a-418a-becf-3123cd33b202} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1088, line 1090) (in query: SELECT quantilesTimingWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:24:10.923716 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:10.984027 [ 18700 ] {77992408-9923-4b8b-a16f-f39f0b557840} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 609.43 MiB (attempt to allocate chunk of 16.46 MiB bytes), current RSS: 15.29 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION fuzzBits(_CAST('\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0'_FixedString(200), 'FixedString(200)'_String) :: 1, 0.99_Float64 :: 2) -> fuzzBits(_CAST('\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0'_FixedString(200), 'FixedString(200)'_String), 0.99_Float64) FixedString(200) : 3'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59806) (comment: 02148_issue_32737.sql) (query 3, line 3) (in query: SELECT fuzzBits(toFixedString('', 200), 0.99) from numbers(60000) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. DB::(anonymous namespace)::FunctionFuzzBits::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eeb71fe 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:24:11.047031 [ 16233 ] {c6b91da2-33ce-40f1-9664-c269265a0cc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1089, line 1091) (in query: SELECT queryID([NULL], [NULL], [NULL]);) 2025.11.13 09:24:11.061189 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:11.077974 [ 18700 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 609.43 MiB (attempt to allocate chunk of 16.46 MiB bytes), current RSS: 15.29 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION fuzzBits(_CAST('\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0'_FixedString(200), 'FixedString(200)'_String) :: 1, 0.99_Float64 :: 2) -> fuzzBits(_CAST('\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0'_FixedString(200), 'FixedString(200)'_String), 0.99_Float64) FixedString(200) : 3'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. DB::(anonymous namespace)::FunctionFuzzBits::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000eeb71fe 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 18. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 19. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 20. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:24:11.135623 [ 16233 ] {c2a7e176-2ec7-4947-9deb-edf0a7418489} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1090, line 1092) (in query: SELECT queryString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:11.149279 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:11.214515 [ 16233 ] {4ca0c80a-d0f1-4a70-99b7-b23b153a79a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1091, line 1093) (in query: SELECT queryStringAndFragment([NULL], [NULL], [NULL]);) 2025.11.13 09:24:11.229033 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:11.388818 [ 16233 ] {61831d72-a1ee-4bae-a248-d9b70ed515a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1092, line 1094) (in query: SELECT query_id([NULL], [NULL], [NULL]);) 2025.11.13 09:24:11.405925 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:11.486562 [ 16233 ] {68975fcc-e020-4551-8043-d0ed383511ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1093, line 1095) (in query: SELECT radians([NULL], [NULL], [NULL]);) 2025.11.13 09:24:11.499609 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:11.614430 [ 16233 ] {8204a7f3-326c-4056-aa13-d965e8103a6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1094, line 1096) (in query: SELECT rand([NULL], [NULL], [NULL]);) 2025.11.13 09:24:11.628597 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:11.760259 [ 16233 ] {52b1e669-effd-4739-bad4-04cd66b81366} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1095, line 1097) (in query: SELECT rand32([NULL], [NULL], [NULL]);) 2025.11.13 09:24:11.781367 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:12.075166 [ 16233 ] {f82a4368-5914-40f3-8d32-9cc247dbbb18} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1096, line 1098) (in query: SELECT rand64([NULL], [NULL], [NULL]);) 2025.11.13 09:24:12.089134 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:12.157303 [ 16233 ] {840a8600-9913-4c4d-a2fb-b17ac991a31b} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1097, line 1099) (in query: SELECT randBernoulli([NULL], [NULL], [NULL]);) 2025.11.13 09:24:12.172586 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:12.238985 [ 18149 ] {47bd6927-5788-414a-9ca5-96595c69a618} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 8, line 10) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree PRIMARY KEY d ORDER BY tuple() SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:676: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482658 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:12.249916 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:676: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482658 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:12.605798 [ 16233 ] {54ee542d-8297-4049-9fe3-a6d59bb26791} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randBinomial, expected Float64 or integer: In scope SELECT randBinomial([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1098, line 1100) (in query: SELECT randBinomial([NULL], [NULL], [NULL]);) 2025.11.13 09:24:12.626429 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randBinomial, expected Float64 or integer: In scope SELECT randBinomial([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:12.688478 [ 16233 ] {5e7bd8df-7b65-4343-97b3-5adca297fbd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1099, line 1101) (in query: SELECT randCanonical([NULL], [NULL], [NULL]);) 2025.11.13 09:24:12.704397 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:12.784483 [ 16233 ] {9acb0af8-04c6-4e9f-afee-a56b012063da} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1100, line 1102) (in query: SELECT randChiSquared([NULL], [NULL], [NULL]);) 2025.11.13 09:24:12.798527 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:12.912490 [ 16233 ] {816135c0-2c93-42ba-bd93-f3f742b2a14e} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1101, line 1103) (in query: SELECT randConstant([NULL], [NULL], [NULL]);) 2025.11.13 09:24:12.933275 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:13.105307 [ 16233 ] {7356778c-882d-4e33-bb39-e0bfe81a3725} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1102, line 1104) (in query: SELECT randExponential([NULL], [NULL], [NULL]);) 2025.11.13 09:24:13.116809 [ 17385 ] {467c2758-ab6e-4d04-b012-79f12f9bde5a} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 517.83 MiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47694) (comment: 01825_new_type_json_6.sh) (query 1, line 1) (in query: INSERT INTO t_json_6 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:24:13.127149 [ 18392 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 515.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:13.133978 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:13.140336 [ 17385 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 517.83 MiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:24:13.166497 [ 16186 ] {72086633-ee76-4909-9a96-b58970b495b0} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 514.62 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59824) (comment: 01603_decimal_mult_float.sql) (query 10, line 19) (in query: SELECT round(sum(f64 * toDecimal64(80, 2)), 6) FROM test01603;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:13.190735 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_217_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 513.67 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column value7): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_217_217_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1062): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:13.193183 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_217_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 513.67 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column value7): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_217_217_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1062): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:13.226314 [ 16233 ] {b5867d12-957e-431c-9567-8391a1d32d4a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randFisherF, expected Float64 or integer: In scope SELECT randFisherF([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1103, line 1105) (in query: SELECT randFisherF([NULL], [NULL], [NULL]);) 2025.11.13 09:24:13.241357 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randFisherF, expected Float64 or integer: In scope SELECT randFisherF([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:13.247411 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 525.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:13.250293 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 525.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:13.309572 [ 16186 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 514.62 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:24:13.355771 [ 18149 ] {30751cea-c817-4525-80dc-cc89afa56730} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 9, line 11) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree PARTITION BY d ORDER BY tuple() SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:13.369406 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:13.389641 [ 16233 ] {742601af-db47-4a73-932f-3d4724a880fd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randLogNormal, expected Float64 or integer: In scope SELECT randLogNormal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1104, line 1106) (in query: SELECT randLogNormal([NULL], [NULL], [NULL]);) 2025.11.13 09:24:13.406892 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randLogNormal, expected Float64 or integer: In scope SELECT randLogNormal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:13.478982 [ 18149 ] {db707923-c2b7-4126-8afc-4900d90501b0} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 10, line 12) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree PARTITION BY tuple(d) ORDER BY tuple() SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:13.490899 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:13.492053 [ 16233 ] {9f96f5ac-1685-4e83-a985-2e1ff9d7b439} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randNegativeBinomial, expected Float64 or integer: In scope SELECT randNegativeBinomial([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1105, line 1107) (in query: SELECT randNegativeBinomial([NULL], [NULL], [NULL]);) 2025.11.13 09:24:13.509225 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randNegativeBinomial, expected Float64 or integer: In scope SELECT randNegativeBinomial([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:13.575533 [ 16233 ] {a560e27d-7e96-4d6c-9409-d781e34bcd44} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randNormal, expected Float64 or integer: In scope SELECT randNormal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1106, line 1108) (in query: SELECT randNormal([NULL], [NULL], [NULL]);) 2025.11.13 09:24:13.594150 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randNormal, expected Float64 or integer: In scope SELECT randNormal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:13.852203 [ 16233 ] {de1c8548-a499-4baa-bb46-19ecbb1d8eb4} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1107, line 1109) (in query: SELECT randPoisson([NULL], [NULL], [NULL]);) 2025.11.13 09:24:13.968533 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:14.084069 [ 16233 ] {51d83db3-3bd8-44aa-b506-e21150841f5b} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1108, line 1110) (in query: SELECT randStudentT([NULL], [NULL], [NULL]);) 2025.11.13 09:24:14.125020 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:14.186888 [ 16233 ] {1c64ab83-cadc-41a9-aba1-d0cce5521dcb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randUniform, expected Float64 or integer: In scope SELECT randUniform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1109, line 1111) (in query: SELECT randUniform([NULL], [NULL], [NULL]);) 2025.11.13 09:24:14.269103 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randUniform, expected Float64 or integer: In scope SELECT randUniform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:14.338367 [ 16233 ] {1e65300c-fc86-4cfc-adc6-de5f38d883ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1110, line 1112) (in query: SELECT randomFixedString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:14.383471 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:14.509199 [ 16233 ] {43c18300-8853-472d-afad-d33b9027a4b6} executeQuery: Code: 42. DB::Exception: Function randomPrintableASCII requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomPrintableASCII([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1111, line 1113) (in query: SELECT randomPrintableASCII([NULL], [NULL], [NULL]);) 2025.11.13 09:24:14.527939 [ 18149 ] {b4977cd7-24a5-4d6d-90e8-8b9dc29f70cb} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 11, line 13) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree PARTITION BY [d] ORDER BY tuple() SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:14.532443 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function randomPrintableASCII requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomPrintableASCII([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:14.538422 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:14.601790 [ 16233 ] {09bc76fe-534f-4364-b624-aaae1537e9f7} executeQuery: Code: 42. DB::Exception: Function randomString requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1112, line 1114) (in query: SELECT randomString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:14.627221 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function randomString requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:14.641872 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:14.643035 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:14.697876 [ 16233 ] {02150193-88ac-4bbc-875c-3aa3056c1fec} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1113, line 1115) (in query: SELECT randomStringUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:14.716275 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:14.785127 [ 16233 ] {aaaaeb69-242c-4914-b40d-676ff60f224b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function range: In scope SELECT range([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1114, line 1116) (in query: SELECT range([NULL], [NULL], [NULL]);) 2025.11.13 09:24:14.809224 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function range: In scope SELECT range([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:14.995025 [ 16233 ] {29f71ca8-3f3c-4679-97c7-8246907a03c8} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1115, line 1117) (in query: SELECT rank([NULL], [NULL], [NULL]);) 2025.11.13 09:24:15.019565 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:24:15.080131 [ 16233 ] {129ae214-1ab6-4df4-9fff-cceada3a84eb} executeQuery: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1116, line 1118) (in query: SELECT rankCorr([NULL], [NULL], [NULL]);) 2025.11.13 09:24:15.101567 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:15.136052 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.47 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:15.173993 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_1_110_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.47 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:15.240286 [ 16233 ] {afe6bb71-b79a-4dc3-89d8-3aa00c1a1c15} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1117, line 1119) (in query: SELECT readWKTLineString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:15.260179 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:15.320697 [ 16233 ] {a8952d8c-8c87-4d5f-9309-84880118d05d} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1118, line 1120) (in query: SELECT readWKTMultiLineString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:15.343211 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:15.393373 [ 17383 ] {832a4a0d-4519-45b6-884f-4b1759ded19d} executeQuery: Code: 264. DB::Exception: Table test_jg056y6j.mem (53c02149-e06f-4ce1-b36b-e1db4898a063) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47680) (comment: 03208_multiple_joins_with_storage_join.sql) (query 18, line 27) (in query: SELECT * FROM tab ANY LEFT JOIN mem ON k1 = mem.k ANY LEFT JOIN mem AS t ON k2 = t.k ORDER BY tab.v ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e3d25 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:15.398076 [ 16233 ] {7bc567de-96b7-4910-8d27-5b67d4a9b660} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1119, line 1121) (in query: SELECT readWKTMultiPolygon([NULL], [NULL], [NULL]);) 2025.11.13 09:24:15.412889 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:15.417149 [ 17383 ] {} TCPHandler: Code: 264. DB::Exception: Table test_jg056y6j.mem (53c02149-e06f-4ce1-b36b-e1db4898a063) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x00000000385e3d25 5. ./build_docker/./src/Planner/PlannerJoins.cpp:1253: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032cea53e 6. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 7. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:15.576590 [ 16233 ] {4840cfde-0b6e-41a5-a19c-b5fddeaec43a} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1120, line 1122) (in query: SELECT readWKTPoint([NULL], [NULL], [NULL]);) 2025.11.13 09:24:15.596160 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:15.662660 [ 16233 ] {e0e677d5-e416-4fae-894a-5590573320b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1121, line 1123) (in query: SELECT readWKTPolygon([NULL], [NULL], [NULL]);) 2025.11.13 09:24:15.677627 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:15.682581 [ 18149 ] {fcb20f39-817c-4079-8d1b-5a88d70941eb} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 12, line 14) (in query: CREATE TABLE test (`d` Dynamic) ENGINE = MergeTree PARTITION BY map('str', d) ORDER BY tuple() SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:15.693257 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:15.751061 [ 16233 ] {cf2da86a-fef8-414a-a50e-4070bfb21185} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1122, line 1124) (in query: SELECT readWKTRing([NULL], [NULL], [NULL]);) 2025.11.13 09:24:15.760871 [ 18149 ] {8998d9bc-c447-4f66-b8d3-1e6f8b8937ed} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 13, line 16) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree ORDER BY d SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:15.768135 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:15.771886 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:15.916005 [ 18149 ] {3811755c-9393-4a86-9426-be1c629e4f3c} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 14, line 17) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree ORDER BY tuple(d) SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:15.927374 [ 16233 ] {18939fb5-c302-430f-a651-2285e960edcd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT regexpExtract([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1123, line 1125) (in query: SELECT regexpExtract([NULL], [NULL], [NULL]);) 2025.11.13 09:24:15.932564 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 6. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:15.942925 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT regexpExtract([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:15.951788 [ 17385 ] {58c8c5dd-d396-40b8-a613-2ac8e24ecd15} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 14. Bytes expected: 39.: (at row 1) : While executing BinaryRowInputFormat. (CANNOT_READ_ALL_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47800) (comment: 03350_json_parsing_quickly.sql) (query 1, line 3) (in query: SELECT * FROM format(RowBinary, 'x JSON', substring(base64Decode( 'alNPTgr/DUMnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycwJ////////wNuJycnJycnBQAnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycnJycnAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAACcnJycnJycnJyck/0gFAA==' ), 6)) SETTINGS enable_json_type = 1, type_json_skip_duplicated_paths = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./src/IO/ReadHelpers.h:149: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001f9cfa51 6. ./build_docker/./src/DataTypes/Serializations/SerializationObject.cpp:951: DB::SerializationObject::deserializeBinary(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f73efd8 7. ./build_docker/./src/Processors/Formats/Impl/BinaryRowInputFormat.cpp:136: DB::BinaryRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b3f5521 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 19. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:24:16.008895 [ 18106 ] {cf28b556-8fff-4484-8606-f60d775c9f80} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37238) (comment: 00094_union_race_conditions_5.sh) (query 97, line 97) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.009641 [ 16233 ] {5c6a7c1e-abb3-44e6-8878-768bcae446f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1124, line 1126) (in query: SELECT regexpQuoteMeta([NULL], [NULL], [NULL]);) 2025.11.13 09:24:16.024998 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:16.035348 [ 17385 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 14. Bytes expected: 39.: (at row 1) : While executing BinaryRowInputFormat. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000f15764d 4. ./build_docker/./src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f960487 5. ./src/IO/ReadHelpers.h:149: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001f9cfa51 6. ./build_docker/./src/DataTypes/Serializations/SerializationObject.cpp:951: DB::SerializationObject::deserializeBinary(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f73efd8 7. ./build_docker/./src/Processors/Formats/Impl/BinaryRowInputFormat.cpp:136: DB::BinaryRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b3f5521 8. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 10. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 11. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 12. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026814689 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 19. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 2025.11.13 09:24:16.048076 [ 18106 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.093744 [ 18149 ] {006b8de7-b408-4c64-a457-c72aee7f49e7} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 15, line 18) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree ORDER BY [d] SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.103702 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.197575 [ 18149 ] {63b82a4f-e854-45d6-aee4-7740d152bafe} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 16, line 19) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree ORDER BY map('str', d) SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.207423 [ 16233 ] {7e8dd3c6-8d08-407e-b56b-e2c1f947c07d} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1125, line 1127) (in query: SELECT regionHierarchy([NULL], [NULL], [NULL]);) 2025.11.13 09:24:16.210809 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482236 8. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.234052 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:16.319897 [ 18149 ] {80191fcb-4243-4bf1-b92c-471cce88f5a7} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 17, line 20) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree PRIMARY KEY d ORDER BY tuple() SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:676: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482658 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.333890 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:676: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a482658 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.352657 [ 16233 ] {e92ac815-57c6-4c89-a797-da2050a32b78} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function regionIn (must be UInt32): In scope SELECT regionIn([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1126, line 1128) (in query: SELECT regionIn([NULL], [NULL], [NULL]);) 2025.11.13 09:24:16.386400 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function regionIn (must be UInt32): In scope SELECT regionIn([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:16.424489 [ 18149 ] {89a3d4a7-e58a-4bc3-8f7b-787e99f0bc18} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 18, line 21) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree PARTITION BY d ORDER BY tuple() SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.441565 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.524807 [ 16233 ] {a81e17de-f7f0-4d6e-a505-063712ae8f91} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToArea([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1127, line 1129) (in query: SELECT regionToArea([NULL], [NULL], [NULL]);) 2025.11.13 09:24:16.541788 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToArea([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:16.561815 [ 18149 ] {bac1f50e-19c1-4dcc-b667-fe4e9700c9ce} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 19, line 22) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree PARTITION BY tuple(d) ORDER BY tuple() SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.571768 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x00000000383953ff 5. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 14. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.620924 [ 16233 ] {d0038ed3-61b0-48dc-a034-8af20eaa8ffe} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1128, line 1130) (in query: SELECT regionToCity([NULL], [NULL], [NULL]);) 2025.11.13 09:24:16.636675 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:16.683419 [ 19606 ] {31b9d38d-e703-448d-82dc-9e51ff2015d9} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 443.51 MiB (attempt to allocate chunk of 1.93 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (avg_value_size_hint = 211.39004960168344, avg_chars_size = 244.06805952202012, limit = 7060): (while reading column query): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_1_56_10/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 7060): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43628) (comment: 01756_optimize_skip_unused_shards_rewrite_in.sql) (query 15, line 37) (in query: select splitByString('IN', query)[-1] from system.query_log where event_date >= yesterday() and event_time > now() - interval 1 hour and not is_initial_query and query not like '%system%query_log%' and query like concat('%', currentDatabase(), '%AS%id_no%') and type = 'QueryFinish' order by query;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 2025.11.13 09:24:16.731125 [ 16233 ] {26c819f6-2af0-42f6-bfd8-3121eb3604a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToContinent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1129, line 1131) (in query: SELECT regionToContinent([NULL], [NULL], [NULL]);) 2025.11.13 09:24:16.749922 [ 18149 ] {3e88ac24-7251-4905-ac6d-e5a046ce8e34} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 20, line 23) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree PARTITION BY [d] ORDER BY tuple() SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.751902 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToContinent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:16.762038 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.806456 [ 19606 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 443.51 MiB (attempt to allocate chunk of 1.93 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (avg_value_size_hint = 211.39004960168344, avg_chars_size = 244.06805952202012, limit = 7060): (while reading column query): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_1_56_10/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 7060): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.844233 [ 18149 ] {2661281e-da1a-4002-afaf-b8f452e0179f} executeQuery: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 21, line 24) (in query: CREATE TABLE test (`d` Variant(UInt64)) ENGINE = MergeTree PARTITION BY map('str', d) ORDER BY tuple() SETTINGS index_granularity = 31966, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 524843183, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25014438, merge_max_block_size = 10074, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 811784, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 41265, primary_key_compress_block_size = 65325, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.853081 [ 18149 ] {} TCPHandler: Code: 549. DB::Exception: Column with type Variant/Dynamic is not allowed in key expression. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. (DATA_TYPE_CANNOT_BE_USED_IN_KEY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/KeyDescription.cpp:181: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&)::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x000000003839a143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 6. ./build_docker/./src/Storages/KeyDescription.cpp:188: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000038394fdb 7. ./build_docker/./src/Storages/KeyDescription.cpp:93: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000003839711f 8. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:641: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a47f76f 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:ne190107] (*)(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002d8831da 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000384ec9d1 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1820c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:16.902461 [ 16233 ] {2611d326-3fdb-4d82-b065-46c62848e441} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCountry([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1130, line 1132) (in query: SELECT regionToCountry([NULL], [NULL], [NULL]);) 2025.11.13 09:24:16.918493 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCountry([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:17.077786 [ 16233 ] {d8d0dd13-50c5-4bec-be9e-c951b6000fe5} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToDistrict([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1131, line 1133) (in query: SELECT regionToDistrict([NULL], [NULL], [NULL]);) 2025.11.13 09:24:17.096857 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToDistrict([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:17.271401 [ 16233 ] {e1a081b1-3905-47e3-b37a-81700c19ae72} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1132, line 1134) (in query: SELECT regionToName([NULL], [NULL], [NULL]);) 2025.11.13 09:24:17.288856 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:17.367599 [ 16233 ] {5ed57127-0ecd-4cf7-a0ad-ba84ed16fe12} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToPopulation([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1133, line 1135) (in query: SELECT regionToPopulation([NULL], [NULL], [NULL]);) 2025.11.13 09:24:17.383620 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToPopulation([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:17.459522 [ 16233 ] {daa9647d-ec26-4212-8398-9b52cde76e5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToTopContinent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1134, line 1136) (in query: SELECT regionToTopContinent([NULL], [NULL], [NULL]);) 2025.11.13 09:24:17.478647 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToTopContinent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:17.564754 [ 16233 ] {91dc8dc0-0afe-4852-910e-78f3742a01c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1135, line 1137) (in query: SELECT reinterpret([NULL], [NULL], [NULL]);) 2025.11.13 09:24:17.585500 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:17.814814 [ 16233 ] {dffde870-4d87-4d46-bea5-3923b2cca441} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1136, line 1138) (in query: SELECT reinterpretAsDate([NULL], [NULL], [NULL]);) 2025.11.13 09:24:17.830352 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:17.913228 [ 16233 ] {57e002a0-77c6-4778-bdc5-daf9212e196e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1137, line 1139) (in query: SELECT reinterpretAsDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:24:17.930859 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:17.993844 [ 16233 ] {f4eb2e1e-ef74-4fba-a1f8-9ceb6d685cb1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1138, line 1140) (in query: SELECT reinterpretAsFixedString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:18.008432 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:18.072404 [ 16233 ] {2f96bfef-0878-47cd-9506-a5ab704762f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1139, line 1141) (in query: SELECT reinterpretAsFloat32([NULL], [NULL], [NULL]);) 2025.11.13 09:24:18.089997 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:18.304148 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 600.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:18.307304 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 600.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:18.386360 [ 16233 ] {f3294010-81f9-4dc3-825e-5f9c9eea5af8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1140, line 1142) (in query: SELECT reinterpretAsFloat64([NULL], [NULL], [NULL]);) 2025.11.13 09:24:18.401909 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:18.463810 [ 16233 ] {7a6f7900-20c6-4ffa-82e8-092efd0fd49f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1141, line 1143) (in query: SELECT reinterpretAsInt128([NULL], [NULL], [NULL]);) 2025.11.13 09:24:18.477928 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:18.625919 [ 16233 ] {ee511b2f-9114-4a3f-9ea2-830b274f2648} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1142, line 1144) (in query: SELECT reinterpretAsInt16([NULL], [NULL], [NULL]);) 2025.11.13 09:24:18.639248 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:18.717150 [ 16233 ] {0acd7cbd-30d1-4051-ad29-cd1c8ae11d21} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1143, line 1145) (in query: SELECT reinterpretAsInt256([NULL], [NULL], [NULL]);) 2025.11.13 09:24:18.734542 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:18.844295 [ 16233 ] {a4ca93ad-7b31-4e17-8c1b-258e5cf84c22} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1144, line 1146) (in query: SELECT reinterpretAsInt32([NULL], [NULL], [NULL]);) 2025.11.13 09:24:18.952093 [ 18149 ] {4541aac5-ad2e-461a-a20c-1433d67be980} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 27, line 34) (in query: select * from test order by d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4161: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000304aae9c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4172: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304a3674 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5685: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fd170 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:24:18.957925 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:18.961761 [ 18149 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4161: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000304aae9c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4172: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304a3674 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5685: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fd170 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:24:19.093906 [ 16233 ] {e2dc82f1-ad50-4207-b887-04b9e5772f49} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1145, line 1147) (in query: SELECT reinterpretAsInt64([NULL], [NULL], [NULL]);) 2025.11.13 09:24:19.106769 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:19.167719 [ 16233 ] {3791192e-7c95-48f6-95b7-e1ab9a9ac02d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1146, line 1148) (in query: SELECT reinterpretAsInt8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:19.182309 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:19.247515 [ 16233 ] {28006b46-570a-4cd6-bf72-c14d4ce7b5b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1147, line 1149) (in query: SELECT reinterpretAsString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:19.263393 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:19.327594 [ 16233 ] {2e7a890e-c2e6-496c-bbbb-2e05628d13ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1148, line 1150) (in query: SELECT reinterpretAsUInt128([NULL], [NULL], [NULL]);) 2025.11.13 09:24:19.342867 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:19.401210 [ 16233 ] {b3202469-4cb5-4e9b-8075-e8ccd62790b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1149, line 1151) (in query: SELECT reinterpretAsUInt16([NULL], [NULL], [NULL]);) 2025.11.13 09:24:19.415245 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:19.482767 [ 16233 ] {748adfea-2a6d-4489-a557-478822908242} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1150, line 1152) (in query: SELECT reinterpretAsUInt256([NULL], [NULL], [NULL]);) 2025.11.13 09:24:19.500921 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:19.593164 [ 16233 ] {d40a10a0-4eb7-4270-9b95-2eadd8c8ec42} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1151, line 1153) (in query: SELECT reinterpretAsUInt32([NULL], [NULL], [NULL]);) 2025.11.13 09:24:19.606565 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:19.804251 [ 16233 ] {e9b67781-b971-4ae7-8772-153cc4bbcbff} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1152, line 1154) (in query: SELECT reinterpretAsUInt64([NULL], [NULL], [NULL]);) 2025.11.13 09:24:19.824221 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:19.895275 [ 16233 ] {4cc3fdd6-38f0-417d-9dd4-6ef4fe7e3e48} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1153, line 1155) (in query: SELECT reinterpretAsUInt8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:19.912687 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:19.977762 [ 16233 ] {ff2e30e8-a93a-4a91-b7e8-084472688c62} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1154, line 1156) (in query: SELECT reinterpretAsUUID([NULL], [NULL], [NULL]);) 2025.11.13 09:24:19.997339 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:20.089585 [ 16233 ] {9c31bb46-f889-4955-bb79-a54007a8964f} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1155, line 1157) (in query: SELECT repeat([NULL], [NULL], [NULL]);) 2025.11.13 09:24:20.104926 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:20.138738 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 577.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:20.144400 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 568.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:20.148243 [ 17227 ] {7d47d65e-a700-4ab8-9cb2-3cefdcd8ee62} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 572.74 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47838) (comment: 01062_pm_all_join_with_block_continuation.sql) (query 5, line 6) (in query: SELECT count(1) FROM ( SELECT materialize(1) as k, n FROM numbers(10) nums JOIN (SELECT materialize(1) AS k, number n FROM numbers(1000000)) j USING k);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:20.182085 [ 18149 ] {09e72ef0-c089-4d8e-9f42-b752aa069c6a} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 28, line 35) (in query: select * from test order by tuple(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4161: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000304aae9c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000304c5ce9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f3ca730 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4173: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304a3736 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5685: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fd170 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:24:20.182151 [ 17227 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 572.74 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:24:20.190491 [ 16233 ] {fa4a27f7-c9ac-473a-adda-f110cc0f325e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replace([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1156, line 1158) (in query: SELECT replace([NULL], [NULL], [NULL]);) 2025.11.13 09:24:20.260122 [ 18149 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4161: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000304aae9c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000304c5ce9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f3ca730 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4173: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304a3736 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5685: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fd170 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:24:20.260171 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replace([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:20.304883 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 581.96 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:20.307413 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 581.96 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:20.514033 [ 16233 ] {74a32f41-14ac-4915-8d18-4051a1906971} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1157, line 1159) (in query: SELECT replaceAll([NULL], [NULL], [NULL]);) 2025.11.13 09:24:20.530704 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:20.611287 [ 16233 ] {92793436-4082-4e4b-94f2-e656be39834e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceOne'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceOne([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1158, line 1160) (in query: SELECT replaceOne([NULL], [NULL], [NULL]);) 2025.11.13 09:24:20.633625 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceOne'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceOne([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:20.721517 [ 16233 ] {af987a42-5a59-4da8-b903-78abd19da178} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceRegexpAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1159, line 1161) (in query: SELECT replaceRegexpAll([NULL], [NULL], [NULL]);) 2025.11.13 09:24:20.745629 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceRegexpAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:20.807351 [ 16233 ] {9ea12d4a-c6ca-4cdd-9d51-1c1731cb0279} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpOne'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceRegexpOne([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1160, line 1162) (in query: SELECT replaceRegexpOne([NULL], [NULL], [NULL]);) 2025.11.13 09:24:20.823450 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpOne'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceRegexpOne([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:21.111138 [ 16233 ] {309703ff-c896-4f3a-9cf0-0f9f73c28cdb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of aggregate function retention, must be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1162, line 1164) (in query: SELECT retention([NULL], [NULL], [NULL]);) 2025.11.13 09:24:21.128081 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of aggregate function retention, must be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:21.202075 [ 16233 ] {e5071911-411c-4a17-90ab-84a41ba73730} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1163, line 1165) (in query: SELECT reverse([NULL], [NULL], [NULL]);) 2025.11.13 09:24:21.315568 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:21.418867 [ 16233 ] {b31c6dbf-a33b-4c53-93e3-01eb5d16bf99} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1164, line 1166) (in query: SELECT reverseUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:21.435015 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:21.585701 [ 16233 ] {72437906-8114-4e9c-a0e1-20f9d0d33c89} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1165, line 1167) (in query: SELECT revision([NULL], [NULL], [NULL]);) 2025.11.13 09:24:21.621588 [ 18149 ] {cc0502c5-ca03-44f2-95c1-96676940236d} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 29, line 36) (in query: select * from test order by array(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4161: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000304aae9c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000304c5ce9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4173: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304a3736 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5685: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fd170 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:24:21.632137 [ 18149 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4161: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000304aae9c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000304c5ce9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4173: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304a3736 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5685: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fd170 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:24:21.690832 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:21.753759 [ 16233 ] {ec212573-c6c3-406f-bfa9-9ac126b781ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1166, line 1168) (in query: SELECT right([NULL], [NULL], [NULL]);) 2025.11.13 09:24:21.769623 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:21.832530 [ 16233 ] {3d044468-3e91-446b-aa7d-e4eba4dfa96e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPad, should be string: In scope SELECT rightPad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1167, line 1169) (in query: SELECT rightPad([NULL], [NULL], [NULL]);) 2025.11.13 09:24:21.899142 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPad, should be string: In scope SELECT rightPad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:21.962582 [ 16233 ] {b40d12dc-5b09-49f8-982c-49a7dfb7f034} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPadUTF8, should be string: In scope SELECT rightPadUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1168, line 1170) (in query: SELECT rightPadUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:21.981582 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPadUTF8, should be string: In scope SELECT rightPadUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:22.058456 [ 16233 ] {da6edce7-0ef9-451c-9390-c65ead910ce5} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1169, line 1171) (in query: SELECT rightUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:22.075371 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:22.413175 [ 16233 ] {700e61ce-9d65-41ad-a3cf-edc50ea3fce9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT round([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1170, line 1172) (in query: SELECT round([NULL], [NULL], [NULL]);) 2025.11.13 09:24:22.439936 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT round([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:22.567840 [ 16233 ] {5bf5decc-f116-40c9-b7f8-0a486e1b7da0} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1171, line 1173) (in query: SELECT roundAge([NULL], [NULL], [NULL]);) 2025.11.13 09:24:22.588120 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:22.651575 [ 16233 ] {2b9a62d0-4c62-4e8a-836a-8c6fc9b6fb54} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT roundBankers([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1172, line 1174) (in query: SELECT roundBankers([NULL], [NULL], [NULL]);) 2025.11.13 09:24:22.671571 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT roundBankers([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:22.716449 [ 16355 ] {7a60798a-df1c-4903-b5a8-3127890614a1} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38744) (comment: 02981_insert_select_resize_to_max_insert_threads.sh) (query 3, line 15) (in query: CREATE TABLE t4_pr ( n UInt64, ) ENGINE = ReplicatedMergeTree('/clickhouse/tables/02981_insert_select_resize_to_max_insert_threads_test_5/02981_insert_select', '1') ORDER BY n;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:24:22.733237 [ 16355 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:24:22.740287 [ 16233 ] {8e1ed794-d5a9-499b-aa9a-b93c2335ea5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1173, line 1175) (in query: SELECT roundDown([NULL], [NULL], [NULL]);) 2025.11.13 09:24:22.755807 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:22.892311 [ 18149 ] {74668b16-e20d-4cb5-a7af-fe6436a6506a} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 30, line 37) (in query: select * from test order by map('str', d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4161: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000304aae9c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000304c5ce9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4173: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304a3736 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5685: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fd170 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:24:22.901785 [ 18149 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in ORDER BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_order_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4161: DB::QueryAnalyzer::validateSortingKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const::$_0::operator()(DB::IDataType const&) const @ 0x00000000304aae9c 5. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000304c5ce9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4173: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304a3736 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5685: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fd170 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:24:22.904287 [ 16233 ] {6c612451-8340-4f58-8ae8-0653464e0597} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1174, line 1176) (in query: SELECT roundDuration([NULL], [NULL], [NULL]);) 2025.11.13 09:24:22.920755 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:23.100540 [ 16233 ] {65b9cea1-2180-4025-b169-2d70ccddab56} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1175, line 1177) (in query: SELECT roundToExp2([NULL], [NULL], [NULL]);) 2025.11.13 09:24:23.115777 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:23.176087 [ 16233 ] {522118ca-ae19-4d6f-84a5-daa5e93a24e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1176, line 1178) (in query: SELECT rowNumberInAllBlocks([NULL], [NULL], [NULL]);) 2025.11.13 09:24:23.190143 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:23.250776 [ 16233 ] {70ba8426-e16e-42de-a1a1-f77622dde7fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1177, line 1179) (in query: SELECT rowNumberInBlock([NULL], [NULL], [NULL]);) 2025.11.13 09:24:23.265626 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:23.404847 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 492.58 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:23.407602 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 492.58 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:23.545090 [ 16233 ] {f643912e-0919-4a75-8cf7-9e76270bee0f} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1178, line 1180) (in query: SELECT row_number([NULL], [NULL], [NULL]);) 2025.11.13 09:24:23.565690 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.11.13 09:24:23.663096 [ 16233 ] {7342f642-36fd-4798-9e01-5b5694397c96} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPad, should be string: In scope SELECT rpad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1179, line 1181) (in query: SELECT rpad([NULL], [NULL], [NULL]);) 2025.11.13 09:24:23.683093 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPad, should be string: In scope SELECT rpad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:23.759323 [ 16233 ] {93bdeb8e-c559-4cc3-81ab-03c41bf3395b} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1180, line 1183) (in query: SELECT runningAccumulate([NULL], [NULL], [NULL]);) 2025.11.13 09:24:23.775754 [ 16233 ] {} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:24:23.948276 [ 16233 ] {eb8d1ad6-8ddd-49bc-8c52-e56d958ef2bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1181, line 1184) (in query: SELECT runningConcurrency([NULL], [NULL], [NULL]);) 2025.11.13 09:24:24.002632 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:24.227484 [ 16233 ] {b0546dba-4b36-48fe-a9cd-48ff11071d4b} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1182, line 1185) (in query: SELECT runningDifference([NULL], [NULL], [NULL]);) 2025.11.13 09:24:24.246499 [ 16233 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:24:24.296032 [ 18149 ] {bcf8c31d-8803-4492-b3fe-b9b19c2aa156} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 33, line 42) (in query: select * from test group by d;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4255: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000304aec0a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4238: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000304ac781 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5662: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc5f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:24:24.322531 [ 4170 ] {4509bd6f-a479-44df-9470-eef12de1fa05} executeQuery: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38724) (comment: 01387_clear_column_default_depends.sql) (query 7, line 10) (in query: ALTER TABLE test DROP COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1615: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a2f44 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:24.334757 [ 4170 ] {} TCPHandler: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1615: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a2f44 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:24.360624 [ 16233 ] {6c9678e6-570b-43d1-9c0b-e3f99c602b68} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1183, line 1186) (in query: SELECT runningDifferenceStartingWithFirstValue([NULL], [NULL], [NULL]);) 2025.11.13 09:24:24.381538 [ 18149 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4255: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000304aec0a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4238: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000304ac781 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5662: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc5f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:24:24.411133 [ 16233 ] {} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.11.13 09:24:24.450731 [ 18149 ] {e9fb8e74-2b26-45cd-a4fd-a7ee3670b965} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 34, line 43) (in query: select * from test group by tuple(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4255: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000304aec0a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4238: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000304ac781 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5662: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc5f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:24:24.460755 [ 18149 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4255: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000304aec0a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4238: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000304ac781 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5662: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc5f1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:24:24.480732 [ 16233 ] {ecefafbb-bf5e-4418-81ce-a8ee70732181} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1184, line 1187) (in query: SELECT s2CapContains([NULL], [NULL], [NULL]);) 2025.11.13 09:24:24.594221 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:24.652417 [ 16233 ] {616613e2-edff-41c6-8576-9100b27012cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1185, line 1188) (in query: SELECT s2CapUnion([NULL], [NULL], [NULL]);) 2025.11.13 09:24:24.671614 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:24.748403 [ 16233 ] {64f0289d-70cb-4b88-b408-45cb4fe72a46} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1186, line 1189) (in query: SELECT s2CellsIntersect([NULL], [NULL], [NULL]);) 2025.11.13 09:24:24.804468 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:24.863404 [ 16233 ] {19ae1d3f-82c4-4cfa-a67f-d15b18adec3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1187, line 1190) (in query: SELECT s2GetNeighbors([NULL], [NULL], [NULL]);) 2025.11.13 09:24:24.878443 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:24.903930 [ 16047 ] {f85d9193-9dcd-4a0d-8972-c0cb3e102315} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37022) (comment: 01568_window_functions_distributed.sql) (query 10, line 24) (in query: SELECT DISTINCT sum(`__table1`.`number`) OVER (PARTITION BY `__table1`.`p`) AS `x`, max(`__table1`.`number`) OVER (PARTITION BY `__table1`.`p`) AS `y` FROM `test_an55utf8`.`t_01568` AS `__table1` ORDER BY sum(`__table1`.`number`) OVER (PARTITION BY `__table1`.`p`) ASC, max(`__table1`.`number`) OVER (PARTITION BY `__table1`.`p`) ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:24:24.918180 [ 16047 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:24:24.932594 [ 19499 ] {e69ea782-9e9b-441e-aeaa-4cf91ead993a} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Query memory tracker: fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47862) (comment: 01568_window_functions_distributed.sql) (query 10, line 24) (in query: select distinct sum(number) over w as x, max(number) over w as y from remote('127.0.0.{1,2}', '', t_01568) window w as (partition by p) order by x, y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:24:24.951119 [ 16233 ] {b50cb139-f01c-4da3-b544-a50427ddc2d6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of function s2RectAdd. Must be UInt64: In scope SELECT s2RectAdd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1188, line 1191) (in query: SELECT s2RectAdd([NULL], [NULL], [NULL]);) 2025.11.13 09:24:24.968315 [ 19499 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Query memory tracker: fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1.00 MiB), maximum: 9.31 GiB. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003aba7e58 6. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 7. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:24:24.969939 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of function s2RectAdd. Must be UInt64: In scope SELECT s2RectAdd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:25.265830 [ 16233 ] {41a04320-82dc-4c5e-a381-e62348f20e44} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of function s2RectContains. Must be UInt64: In scope SELECT s2RectContains([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1189, line 1192) (in query: SELECT s2RectContains([NULL], [NULL], [NULL]);) 2025.11.13 09:24:25.321517 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of function s2RectContains. Must be UInt64: In scope SELECT s2RectContains([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:25.385999 [ 16233 ] {1a37023d-418b-4685-a431-3906705c9a42} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1190, line 1193) (in query: SELECT s2RectIntersection([NULL], [NULL], [NULL]);) 2025.11.13 09:24:25.403151 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:25.545350 [ 16233 ] {4cee3701-c399-4628-b7e1-8e498747662e} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1191, line 1194) (in query: SELECT s2RectUnion([NULL], [NULL], [NULL]);) 2025.11.13 09:24:25.565236 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:25.738459 [ 16233 ] {9ab726b1-3027-46c4-b6e0-5548cc52cafb} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1192, line 1195) (in query: SELECT s2ToGeo([NULL], [NULL], [NULL]);) 2025.11.13 09:24:25.756961 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:25.889115 [ 16233 ] {f2a4d80f-2e2b-418a-ad45-477ddc1abfe2} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1193, line 1196) (in query: SELECT scalarProduct([NULL], [NULL], [NULL]);) 2025.11.13 09:24:25.906872 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:25.975508 [ 16233 ] {0a4688cf-d046-473b-8fd5-2e08366f88eb} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1194, line 1197) (in query: SELECT sequenceCount([NULL], [NULL], [NULL]);) 2025.11.13 09:24:25.995372 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:26.054609 [ 16233 ] {a7639fc6-4912-47ca-858f-4a203e3dcae7} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1195, line 1198) (in query: SELECT sequenceMatch([NULL], [NULL], [NULL]);) 2025.11.13 09:24:26.070331 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:26.117517 [ 18149 ] {7367ff62-470d-43f1-a60d-81246f9800e5} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 35, line 44) (in query: select array(d) from test group by array(d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4255: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000304c5e83 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4264: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000304aea8f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4238: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000304ac781 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5662: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc5f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:24:26.129076 [ 18149 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4255: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000304c5e83 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f306662 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4264: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000304aea8f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4238: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000304ac781 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5662: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc5f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:24:26.135358 [ 16233 ] {ad74f23a-6c43-4b0b-abd4-08da9e492101} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatchEvents requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1196, line 1199) (in query: SELECT sequenceMatchEvents([NULL], [NULL], [NULL]);) 2025.11.13 09:24:26.151102 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatchEvents requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:26.186477 [ 16231 ] {8ca7c21d-cdc1-4eeb-a42f-186c253d5e49} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't4_pr' in scope SELECT * FROM t4_pr. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38804) (comment: 02981_insert_select_resize_to_max_insert_threads.sh) (query 1, line 2) (in query: EXPLAIN PIPELINE INSERT INTO t3_dist SELECT * FROM t4_pr;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ad54c5 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000032ae00c9 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:600: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000032a81fb0 14. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000032a7c4c4 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:24:26.202953 [ 16231 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't4_pr' in scope SELECT * FROM t4_pr. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ad54c5 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000032ae00c9 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:600: DB::InterpreterExplainQuery::executeImpl() @ 0x0000000032a81fb0 14. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000032a7c4c4 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:24:26.295516 [ 16233 ] {8f962bc0-d8d0-4cc4-9103-5223ff4fff2e} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1197, line 1200) (in query: SELECT sequenceNextNode([NULL], [NULL], [NULL]);) 2025.11.13 09:24:26.312130 [ 16233 ] {} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.11.13 09:24:26.417832 [ 16233 ] {ea8a7415-853c-4171-b06a-3b33e94067c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1198, line 1201) (in query: SELECT seriesDecomposeSTL([NULL], [NULL], [NULL]);) 2025.11.13 09:24:26.525327 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:26.681721 [ 16233 ] {3cdfcdf1-e122-4cc2-8637-13dccd626109} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 3.: In scope SELECT seriesOutliersDetectTukey([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1199, line 1202) (in query: SELECT seriesOutliersDetectTukey([NULL], [NULL], [NULL]);) 2025.11.13 09:24:26.701200 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 3.: In scope SELECT seriesOutliersDetectTukey([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:26.781524 [ 16233 ] {90756ed7-67d7-4b65-9e82-db2e02501e8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1200, line 1203) (in query: SELECT seriesPeriodDetectFFT([NULL], [NULL], [NULL]);) 2025.11.13 09:24:26.800210 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:27.001530 [ 16233 ] {e2322c5a-ddde-478b-b73b-e8ef2cc93f78} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1201, line 1204) (in query: SELECT serverTimeZone([NULL], [NULL], [NULL]);) 2025.11.13 09:24:27.034644 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:27.210853 [ 16233 ] {e81d17f3-d692-4842-ad5f-93fa926c2983} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1202, line 1205) (in query: SELECT serverTimezone([NULL], [NULL], [NULL]);) 2025.11.13 09:24:27.231172 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:27.332158 [ 4170 ] {d9f5fced-0121-4b68-9892-a86f7fcba737} executeQuery: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38724) (comment: 01387_clear_column_default_depends.sql) (query 15, line 19) (in query: ALTER TABLE test DROP COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1615: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a2f44 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:27.371639 [ 16233 ] {1e7f84ab-6d51-4984-a059-42a233d4c104} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1203, line 1206) (in query: SELECT serverUUID([NULL], [NULL], [NULL]);) 2025.11.13 09:24:27.386132 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:27.419169 [ 4170 ] {} TCPHandler: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1615: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a2f44 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:27.447342 [ 16233 ] {838c897b-a37d-48a4-9417-6ccbafabbe94} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1204, line 1207) (in query: SELECT shardCount([NULL], [NULL], [NULL]);) 2025.11.13 09:24:27.463118 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:27.591310 [ 16233 ] {2d567628-f601-41f3-bc7d-41ee45590776} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1205, line 1208) (in query: SELECT shardNum([NULL], [NULL], [NULL]);) 2025.11.13 09:24:27.607923 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:27.675666 [ 16233 ] {8ee4a990-328b-4d6c-b1a0-fa7af90b767e} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1206, line 1209) (in query: SELECT showCertificate([NULL], [NULL], [NULL]);) 2025.11.13 09:24:27.690476 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:27.693689 [ 18149 ] {1ed31a64-70d0-448b-ba5e-ccd59213f2bb} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 36, line 45) (in query: select map('str', d) from test group by map('str', d);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4255: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000304c5e83 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4264: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000304aea8f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4238: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000304ac781 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5662: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc5f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:24:27.703617 [ 18149 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4255: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, DB::IdentifierResolveScope const&) const::$_0, void (DB::IDataType const&)>>(std::__function::__policy_storage const*, DB::IDataType const&) @ 0x00000000304c5e83 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f371255 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4264: DB::QueryAnalyzer::validateGroupByKeyType(std::shared_ptr const&, DB::IdentifierResolveScope const&) const @ 0x00000000304aea8f 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4238: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000304ac781 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5662: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc5f1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:24:27.750242 [ 16233 ] {ec425f10-642b-47dc-b257-e12dfbc67456} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1207, line 1210) (in query: SELECT sigmoid([NULL], [NULL], [NULL]);) 2025.11.13 09:24:27.767156 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:27.834805 [ 16233 ] {00a80ad0-3b19-4072-9434-fb0184619cb2} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1208, line 1211) (in query: SELECT sign([NULL], [NULL], [NULL]);) 2025.11.13 09:24:27.851699 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:27.993648 [ 16233 ] {c8038d9f-1e56-4859-9743-e63edfb9bd78} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1209, line 1212) (in query: SELECT simpleJSONExtractBool([NULL], [NULL], [NULL]);) 2025.11.13 09:24:28.009093 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:28.167165 [ 16233 ] {dc64ca5d-1b28-4ff1-a43e-ff2ea712ea06} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1210, line 1213) (in query: SELECT simpleJSONExtractFloat([NULL], [NULL], [NULL]);) 2025.11.13 09:24:28.180800 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:28.337051 [ 16233 ] {13624ea6-6c25-4a51-bf00-398f5352f214} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1211, line 1214) (in query: SELECT simpleJSONExtractInt([NULL], [NULL], [NULL]);) 2025.11.13 09:24:28.354205 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:28.494398 [ 16233 ] {056eb208-9939-49ea-84cd-70a42081ca62} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1212, line 1215) (in query: SELECT simpleJSONExtractRaw([NULL], [NULL], [NULL]);) 2025.11.13 09:24:28.576283 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:28.600330 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 672.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6bfcf6 24. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7e7388 25. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 27. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 29. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 30. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 31. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:28.604756 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 672.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:32: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6bfcf6 24. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:693: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7e7388 25. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 27. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 29. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 30. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 31. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:28.734775 [ 16233 ] {093eb274-c4f7-40e5-bec3-af12155a234b} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1213, line 1216) (in query: SELECT simpleJSONExtractString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:28.748820 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:28.784839 [ 18149 ] {d0b433ff-1fc4-4b12-b962-6cf791e3651b} executeQuery: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 37, line 46) (in query: select * from test group by grouping sets ((d), ('str'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4255: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000304acd68 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5662: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc5f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:28.805917 [ 16233 ] {d8d4eb74-f95b-4c7f-9b2e-dc3e1dc328c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1214, line 1217) (in query: SELECT simpleJSONExtractUInt([NULL], [NULL], [NULL]);) 2025.11.13 09:24:28.828783 [ 18149 ] {} TCPHandler: Code: 44. DB::Exception: Data types Variant/Dynamic are not allowed in GROUP BY keys, because it can lead to unexpected results. Consider using a subcolumn with a specific data type instead (for example 'column.Int64' or 'json.some.path.:Int64' if its a JSON path subcolumn) or casting this column to a specific data type. Set setting allow_suspicious_types_in_group_by = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4255: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x00000000304acd68 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5662: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fc5f1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:28.917922 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:29.059183 [ 16233 ] {1b0f958a-a09a-4bcb-ae94-1dd10d42b438} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1215, line 1218) (in query: SELECT simpleJSONHas([NULL], [NULL], [NULL]);) 2025.11.13 09:24:29.074441 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:29.134995 [ 16233 ] {c6afa43d-6570-4911-841d-bfd4847cdb65} executeQuery: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1216, line 1219) (in query: SELECT simpleLinearRegression([NULL], [NULL], [NULL]);) 2025.11.13 09:24:29.197082 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:29.268084 [ 16233 ] {7aca492f-810f-444c-824b-9a171cd31b4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1217, line 1220) (in query: SELECT sin([NULL], [NULL], [NULL]);) 2025.11.13 09:24:29.347680 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:29.407570 [ 16233 ] {1f2c2eff-f8ca-4bff-812c-13148b81dd73} executeQuery: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1218, line 1221) (in query: SELECT singleValueOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:29.488822 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:29.547068 [ 16233 ] {491ada8f-6e43-454d-8854-965ee994bcf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1219, line 1222) (in query: SELECT sinh([NULL], [NULL], [NULL]);) 2025.11.13 09:24:29.559351 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:29.992252 [ 16233 ] {9afaa38e-05b4-43f2-95d8-9a0ac4a4d2e6} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1221, line 1224) (in query: SELECT sipHash128Keyed([NULL], [NULL], [NULL]);) 2025.11.13 09:24:30.070361 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.11.13 09:24:30.313599 [ 16233 ] {0723dcab-8f46-4fc9-b3fd-704d069b306b} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1223, line 1226) (in query: SELECT sipHash128ReferenceKeyed([NULL], [NULL], [NULL]);) 2025.11.13 09:24:30.329960 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.11.13 09:24:30.393286 [ 4170 ] {990b6c45-373a-4fb9-b575-d8abc498c283} executeQuery: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38724) (comment: 01387_clear_column_default_depends.sql) (query 23, line 28) (in query: ALTER TABLE test DROP COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1615: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a2f44 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:30.402063 [ 4170 ] {} TCPHandler: Code: 44. DB::Exception: Cannot drop column `x`, because column `y` depends on it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/AlterCommands.cpp:1615: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a2f44 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:30.416459 [ 17390 ] {5a495a68-f5bc-4886-a6e6-50870b520a43} executeQuery: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38844) (comment: 02455_improve_feedback_when_replacing_partition_with_different_primary_key.sql) (query 4, line 4) (in query: ALTER TABLE test_b REPLACE PARTITION '0' FROM test_a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7791: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0d7bc 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7822: DB::MergeTreeData::checkStructureAndGetMergeTreeData(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0e23f 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a51dc57 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5806: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000399a5d03 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032992221 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:24:30.427732 [ 17390 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7791: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0d7bc 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7822: DB::MergeTreeData::checkStructureAndGetMergeTreeData(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000039a0e23f 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000003a51dc57 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5806: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000399a5d03 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032992221 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:24:30.516631 [ 16233 ] {f2f75ea9-9cd0-4529-8412-faf52be1858d} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1225, line 1228) (in query: SELECT sipHash64Keyed([NULL], [NULL], [NULL]);) 2025.11.13 09:24:30.529769 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.11.13 09:24:30.729370 [ 16354 ] {944d38cf-c377-4da0-aeec-bc91057fc0e5} executeQuery: Code: 60. DB::Exception: Table test_buj78wwa.async_inserts1 does not exist. Maybe you meant test_buj78wwa.async_inserts?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34662) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts1 FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003166d8ce 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000003166fefc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382ccd7 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:24:30.738026 [ 16354 ] {944d38cf-c377-4da0-aeec-bc91057fc0e5} DynamicQueryHandler: Code: 60. DB::Exception: Table test_buj78wwa.async_inserts1 does not exist. Maybe you meant test_buj78wwa.async_inserts?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:342: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003166d8ce 9. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000003166fefc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382ccd7 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 12. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 13. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:30.806451 [ 16233 ] {8fd6ff69-748b-4138-bfb3-f0fabb544f5c} executeQuery: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1226, line 1229) (in query: SELECT skewPop([NULL], [NULL], [NULL]);) 2025.11.13 09:24:30.824695 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:30.878179 [ 16233 ] {2aea00d0-9e3a-4dec-ba29-28b86304a710} executeQuery: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1227, line 1230) (in query: SELECT skewSamp([NULL], [NULL], [NULL]);) 2025.11.13 09:24:30.891880 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:30.945231 [ 16233 ] {78d3c832-c9ac-4c97-8b31-674ae19a149a} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1228, line 1231) (in query: SELECT sleep([NULL], [NULL], [NULL]);) 2025.11.13 09:24:30.958553 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:31.012996 [ 16233 ] {93d20289-15dd-4126-b190-0bd902c51d4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1229, line 1232) (in query: SELECT sleepEachRow([NULL], [NULL], [NULL]);) 2025.11.13 09:24:31.026435 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:31.135647 [ 16233 ] {c4286246-ec8a-4bcb-a790-a11710fd6a5c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Array(Nullable(Nothing)): In scope SELECT snowflakeIDToDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1230, line 1233) (in query: SELECT snowflakeIDToDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:24:31.154178 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Array(Nullable(Nothing)): In scope SELECT snowflakeIDToDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:31.220872 [ 16233 ] {d2a9f546-9fba-4025-8fc8-6cabd80d0dcf} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Array(Nullable(Nothing)): In scope SELECT snowflakeIDToDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1231, line 1234) (in query: SELECT snowflakeIDToDateTime64([NULL], [NULL], [NULL]);) 2025.11.13 09:24:31.239206 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Array(Nullable(Nothing)): In scope SELECT snowflakeIDToDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:31.257110 [ 17390 ] {597f6579-0529-429c-8e9e-c36f914608fa} executeQuery: Code: 73. DB::Exception: Unknown input format BadFormat. (UNKNOWN_FORMAT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43930) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts FORMAT BadFormat ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:356: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003166f1f7 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000003166fefc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382ccd7 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:31.265465 [ 17390 ] {597f6579-0529-429c-8e9e-c36f914608fa} DynamicQueryHandler: Code: 73. DB::Exception: Unknown input format BadFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:356: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003166f1f7 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000003166fefc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382ccd7 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:31.311734 [ 18728 ] {1edafba0-768e-465f-91f6-cbf8c7c74e61} executeQuery: Code: 73. DB::Exception: Unknown input format Pretty. (UNKNOWN_FORMAT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43940) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts FORMAT Pretty ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:356: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003166f1f7 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000003166fefc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382ccd7 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:31.320483 [ 18728 ] {1edafba0-768e-465f-91f6-cbf8c7c74e61} DynamicQueryHandler: Code: 73. DB::Exception: Unknown input format Pretty. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:356: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003166f1f7 5. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000003166fefc 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382ccd7 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 8. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 9. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:31.363334 [ 18149 ] {93c817d2-425e-4094-8e7d-77b74751bc05} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59754) (comment: 03231_dynamic_variant_in_order_by_group_by.sql) (query 49, line 62) (in query: set allow_experimental_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:24:31.370995 [ 18149 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:24:31.377902 [ 16233 ] {63cba6a2-faf1-4e98-9473-eb256886a2b3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1232, line 1235) (in query: SELECT snowflakeToDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:24:31.393257 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:31.523653 [ 16233 ] {5a20a4ad-0cb3-4b3d-82e7-4542969cc234} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1233, line 1236) (in query: SELECT snowflakeToDateTime64([NULL], [NULL], [NULL]);) 2025.11.13 09:24:31.538330 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:31.598930 [ 16233 ] {a21f38e4-d3ec-4b66-9137-02e4cb8c0fc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1234, line 1237) (in query: SELECT soundex([NULL], [NULL], [NULL]);) 2025.11.13 09:24:31.611538 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:31.669999 [ 16233 ] {8a7b45c3-a1f0-442e-9084-fe5dbc73f4c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1235, line 1238) (in query: SELECT space([NULL], [NULL], [NULL]);) 2025.11.13 09:24:31.683179 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:31.737498 [ 16233 ] {375150a5-f98d-4553-8f38-3cd33a286b3c} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1236, line 1239) (in query: SELECT sparkBar([NULL], [NULL], [NULL]);) 2025.11.13 09:24:31.752602 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:31.817711 [ 16233 ] {5eef1b17-1ad8-4da8-be7d-d0509b1b5d08} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1237, line 1240) (in query: SELECT sparkbar([NULL], [NULL], [NULL]);) 2025.11.13 09:24:31.887606 [ 17390 ] {8db42fae-52aa-44f2-a44b-855dd4e5b967} executeQuery: Code: 16. DB::Exception: No such column a in table test_buj78wwa.async_inserts (6f810338-2b1f-4308-b760-c2bb622f7ee5). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43946) (comment: 02015_async_inserts_6.sh) (in query: INSERT INTO async_inserts (id, a) FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x0000000032ac85ed 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000032ac6302 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:343: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003166db9b 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000003166fefc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382ccd7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:24:31.929542 [ 17390 ] {8db42fae-52aa-44f2-a44b-855dd4e5b967} DynamicQueryHandler: Code: 16. DB::Exception: No such column a in table test_buj78wwa.async_inserts (6f810338-2b1f-4308-b760-c2bb622f7ee5). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x0000000032ac85ed 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000032ac6302 6. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:343: DB::AsynchronousInsertQueue::preprocessInsertQuery(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003166db9b 7. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:373: DB::AsynchronousInsertQueue::pushQueryWithInlinedData(std::shared_ptr, std::shared_ptr) @ 0x000000003166fefc 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1284: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382ccd7 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 10. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 11. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:31.930117 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:31.994969 [ 16233 ] {ddcbb957-01d4-4f6a-8889-0ec19efdadf3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByAlpha([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1238, line 1241) (in query: SELECT splitByAlpha([NULL], [NULL], [NULL]);) 2025.11.13 09:24:32.049550 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByAlpha([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:32.115060 [ 16233 ] {f88adba9-39f6-48c0-a246-4c7375d59573} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByChar'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByChar([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1239, line 1242) (in query: SELECT splitByChar([NULL], [NULL], [NULL]);) 2025.11.13 09:24:32.133294 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByChar'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByChar([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:32.202731 [ 16233 ] {6607b2cf-bd5f-4bc7-b005-bed054f32a99} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByNonAlpha([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1240, line 1243) (in query: SELECT splitByNonAlpha([NULL], [NULL], [NULL]);) 2025.11.13 09:24:32.218956 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByNonAlpha([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:32.296283 [ 16233 ] {d6e43519-b761-4393-adfe-4aa7a9bc4109} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByRegexp'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByRegexp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1241, line 1244) (in query: SELECT splitByRegexp([NULL], [NULL], [NULL]);) 2025.11.13 09:24:32.312984 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByRegexp'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByRegexp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:32.369836 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 626.24 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:32.371991 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 626.24 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:32.375033 [ 16233 ] {8861b32d-40d0-4cdc-825c-7bb690093d6c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByString'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1242, line 1245) (in query: SELECT splitByString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:32.481763 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByString'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:32.597972 [ 16233 ] {7c3773c7-6a7f-46f5-9424-6a657799c7b3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByWhitespace([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1243, line 1246) (in query: SELECT splitByWhitespace([NULL], [NULL], [NULL]);) 2025.11.13 09:24:32.613982 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByWhitespace([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:32.803194 [ 16233 ] {29d9a31a-fb98-4246-901e-02d71cdc36c5} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nullable(Nothing)).: In scope SELECT sqid([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1244, line 1247) (in query: SELECT sqid([NULL], [NULL], [NULL]);) 2025.11.13 09:24:32.816841 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nullable(Nothing)).: In scope SELECT sqid([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:32.886283 [ 16233 ] {428505e5-2f14-4e59-94b8-27448beb4a94} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1245, line 1248) (in query: SELECT sqidDecode([NULL], [NULL], [NULL]);) 2025.11.13 09:24:32.899764 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:32.963498 [ 16233 ] {4fdfe298-db2d-427f-9a86-e9908e867e9c} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nullable(Nothing)).: In scope SELECT sqidEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1246, line 1249) (in query: SELECT sqidEncode([NULL], [NULL], [NULL]);) 2025.11.13 09:24:32.980435 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nullable(Nothing)).: In scope SELECT sqidEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:33.043430 [ 16233 ] {63c6c37d-42a1-43c4-a9a2-34b04f5170af} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1247, line 1250) (in query: SELECT sqrt([NULL], [NULL], [NULL]);) 2025.11.13 09:24:33.058547 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:33.202278 [ 16233 ] {a1c20f1e-320c-45c3-9e94-e091eefedb24} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1248, line 1251) (in query: SELECT startsWith([NULL], [NULL], [NULL]);) 2025.11.13 09:24:33.215396 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:33.277963 [ 16233 ] {5b13cde1-dd0d-470d-a277-68dca3bfb081} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1249, line 1252) (in query: SELECT startsWithUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:33.290289 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:33.377375 [ 16354 ] {9e6f23b6-8329-41ef-9331-c8479ac13166} executeQuery: Code: 53. DB::Exception: Trying to compare constants of incompatible types (String and Decimal64), please verify that table constraints are defined using correct types, constraints can be ignored by disabling 'optimize_using_constraints'. Constraints for table can be modified using 'ALTER TABLE ... ADD/DROP CONSTRAINT' query. (TYPE_MISMATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55718) (comment: 03362_optimize_using_constraints_type_mismatch.sql) (query 3, line 3) (in query: SELECT 1 FROM t0 WHERE t0.c0 = t0.c0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x000000002eb5e56d 4. ./build_docker/./src/Interpreters/ComparisonGraph.cpp:157: DB::ComparisonGraph>::buildGraphFromNodesGraph(DB::ComparisonGraph>::Graph const&) @ 0x000000003176e7ff 5. ./build_docker/./src/Interpreters/ComparisonGraph.cpp:312: DB::ComparisonGraph>::ComparisonGraph(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000003176769d 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ConstraintsDescription::getQueryTreeData(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003831ea52 7. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:668: DB::(anonymous namespace)::ConvertQueryToCNFVisitor::enterImpl(std::shared_ptr&)::'lambda'(std::shared_ptr&)::operator()(std::shared_ptr&) const @ 0x00000000305d7951 8. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:737: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x00000000305d2091 9. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:755: DB::ConvertLogicalExpressionToCNFPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000305d12e9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:33.386407 [ 16354 ] {} TCPHandler: Code: 53. DB::Exception: Trying to compare constants of incompatible types (String and Decimal64), please verify that table constraints are defined using correct types, constraints can be ignored by disabling 'optimize_using_constraints'. Constraints for table can be modified using 'ALTER TABLE ... ADD/DROP CONSTRAINT' query. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>, std::basic_string_view>>(int, FormatStringHelperImpl>>::type, std::type_identity>>::type>, std::basic_string_view>&&, std::basic_string_view>&&) @ 0x000000002eb5e56d 4. ./build_docker/./src/Interpreters/ComparisonGraph.cpp:157: DB::ComparisonGraph>::buildGraphFromNodesGraph(DB::ComparisonGraph>::Graph const&) @ 0x000000003176e7ff 5. ./build_docker/./src/Interpreters/ComparisonGraph.cpp:312: DB::ComparisonGraph>::ComparisonGraph(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000003176769d 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::ConstraintsDescription::getQueryTreeData(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003831ea52 7. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:668: DB::(anonymous namespace)::ConvertQueryToCNFVisitor::enterImpl(std::shared_ptr&)::'lambda'(std::shared_ptr&)::operator()(std::shared_ptr&) const @ 0x00000000305d7951 8. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:737: DB::InDepthQueryTreeVisitorWithContext::visit(std::shared_ptr&) @ 0x00000000305d2091 9. ./build_docker/./src/Analyzer/Passes/ConvertQueryToCNFPass.cpp:755: DB::ConvertLogicalExpressionToCNFPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000305d12e9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:33.428878 [ 16233 ] {2c956f2a-6983-4c54-8f97-bbf785b5c940} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1250, line 1253) (in query: SELECT stddevPop([NULL], [NULL], [NULL]);) 2025.11.13 09:24:33.534276 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:33.700667 [ 16233 ] {60535549-2c32-4ada-a7bd-914b4af9d501} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1251, line 1254) (in query: SELECT stddevPopStable([NULL], [NULL], [NULL]);) 2025.11.13 09:24:33.723361 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:33.875722 [ 16233 ] {a9bd7c67-f665-44fc-ad88-fbd5eda07d77} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1252, line 1255) (in query: SELECT stddevSamp([NULL], [NULL], [NULL]);) 2025.11.13 09:24:33.893918 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:34.064201 [ 16233 ] {bd9edfce-a032-422c-bf3e-5cc98ac46e38} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1253, line 1256) (in query: SELECT stddevSampStable([NULL], [NULL], [NULL]);) 2025.11.13 09:24:34.077286 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:34.137244 [ 16233 ] {735d6902-d22a-45a2-8990-e15ef649da69} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1254, line 1257) (in query: SELECT stem([NULL], [NULL], [NULL]);) 2025.11.13 09:24:34.159433 [ 16233 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:24:34.235965 [ 16233 ] {4fd996f3-61e3-4120-a1ee-ee8ea4303154} executeQuery: Code: 43. DB::Exception: Argument 0 of type Array(Nullable(Nothing)) must be numeric for aggregate function stochasticLinearRegression. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1255, line 1258) (in query: SELECT stochasticLinearRegression([NULL], [NULL], [NULL]);) 2025.11.13 09:24:34.285126 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of type Array(Nullable(Nothing)) must be numeric for aggregate function stochasticLinearRegression. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:34.346101 [ 16233 ] {d8e33249-3083-4916-81fb-82b04d3ea4b1} executeQuery: Code: 43. DB::Exception: Argument 0 of type Array(Nullable(Nothing)) must be numeric for aggregate function stochasticLogisticRegression. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1256, line 1259) (in query: SELECT stochasticLogisticRegression([NULL], [NULL], [NULL]);) 2025.11.13 09:24:34.365108 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Argument 0 of type Array(Nullable(Nothing)) must be numeric for aggregate function stochasticLogisticRegression. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:34.561458 [ 16233 ] {90726434-d18e-4534-97dc-c188876edc28} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT str_to_date([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1257, line 1260) (in query: SELECT str_to_date([NULL], [NULL], [NULL]);) 2025.11.13 09:24:34.577114 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT str_to_date([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:34.634258 [ 16233 ] {491b850f-56ee-4db5-8da0-a47a075d5510} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT str_to_map([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1258, line 1261) (in query: SELECT str_to_map([NULL], [NULL], [NULL]);) 2025.11.13 09:24:34.647565 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT str_to_map([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:34.755239 [ 16233 ] {58ebdbb5-784e-4947-b8e6-e6144d29d594} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1259, line 1262) (in query: SELECT stringJaccardIndex([NULL], [NULL], [NULL]);) 2025.11.13 09:24:34.805079 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:34.872713 [ 16233 ] {ec79615c-65f1-4e0d-8ba2-977ec3afe333} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1260, line 1263) (in query: SELECT stringJaccardIndexUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:34.886620 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:34.920338 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 579.80 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:34.922960 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 579.80 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:34.954720 [ 16233 ] {5453e950-0b4f-4d17-922c-35ce0652e29a} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1261, line 1264) (in query: SELECT stringToH3([NULL], [NULL], [NULL]);) 2025.11.13 09:24:34.976175 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:35.029591 [ 17228 ] {deadeb61-a208-44f6-b083-1fe6736acf8c} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55796) (comment: 00732_quorum_insert_simple_test_1_parts_zookeeper_long.sql) (query 4, line 10) (in query: CREATE TABLE quorum1 (`x` UInt32, `y` Date) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00732/quorum1', '1') PARTITION BY y ORDER BY x SETTINGS index_granularity = 15704, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.7001901268959045, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 178463581, compact_parts_max_bytes_to_buffer = 353823738, compact_parts_max_granules_to_buffer = 93, compact_parts_merge_max_bytes_to_prefetch_part = 14567190, merge_max_block_size = 7333, old_parts_lifetime = 331., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 9210139, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 40524, primary_key_compress_block_size = 42239, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:24:35.041788 [ 17228 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:24:35.115556 [ 16233 ] {8fc37a25-0111-4a4e-8edc-4aa0ffd42a9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1262, line 1265) (in query: SELECT structureToCapnProtoSchema([NULL], [NULL], [NULL]);) 2025.11.13 09:24:35.148638 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:35.347068 [ 16233 ] {7d4e2e09-0f93-4178-9ed4-b7cc79fd257e} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1263, line 1266) (in query: SELECT structureToProtobufSchema([NULL], [NULL], [NULL]);) 2025.11.13 09:24:35.373827 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:35.436853 [ 16233 ] {a4eff3f4-a84e-420f-83f1-9e461fee41a5} executeQuery: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1264, line 1267) (in query: SELECT studentTTest([NULL], [NULL], [NULL]);) 2025.11.13 09:24:35.453108 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:35.546677 [ 16233 ] {94e08c8f-6eb1-4caf-b4a0-2e924f7cb8b2} executeQuery: Code: 43. DB::Exception: First argument for function subBitmap must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT subBitmap([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1265, line 1268) (in query: SELECT subBitmap([NULL], [NULL], [NULL]);) 2025.11.13 09:24:35.561214 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function subBitmap must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT subBitmap([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:35.667674 [ 16233 ] {96e9be75-8e60-4e2c-905b-d8b60df6a3fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1266, line 1269) (in query: SELECT subDate([NULL], [NULL], [NULL]);) 2025.11.13 09:24:35.681782 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:35.898263 [ 16233 ] {eff1d25d-701d-43ad-894d-228aa48f017a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1267, line 1270) (in query: SELECT substr([NULL], [NULL], [NULL]);) 2025.11.13 09:24:36.003446 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:36.066219 [ 16233 ] {2691ca7b-1087-4448-99bd-1e69ae2c7250} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substring([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1268, line 1271) (in query: SELECT substring([NULL], [NULL], [NULL]);) 2025.11.13 09:24:36.080882 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substring([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:36.134869 [ 16233 ] {7c01a273-6db7-44f6-8456-9482f6e9df4b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndex, String expected: In scope SELECT substringIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1269, line 1272) (in query: SELECT substringIndex([NULL], [NULL], [NULL]);) 2025.11.13 09:24:36.148120 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndex, String expected: In scope SELECT substringIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:36.209286 [ 16233 ] {db029528-269b-4d18-b2f3-37ca31ef1539} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndexUTF8, String expected: In scope SELECT substringIndexUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1270, line 1273) (in query: SELECT substringIndexUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:36.223082 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndexUTF8, String expected: In scope SELECT substringIndexUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:36.368576 [ 16233 ] {a34f7816-c937-42c0-97bc-b02364aa652a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringUTF8, expected String: In scope SELECT substringUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1271, line 1274) (in query: SELECT substringUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:36.382064 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringUTF8, expected String: In scope SELECT substringUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:36.592254 [ 16233 ] {a57fb114-abd5-47a0-87d4-ee920edf2622} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope SELECT subtractDays([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1272, line 1275) (in query: SELECT subtractDays([NULL], [NULL], [NULL]);) 2025.11.13 09:24:36.675247 [ 16207 ] {1851fd03-734b-4f9a-a20a-4b66cab77986} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 2 (error): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE, EXECUTE AS query, EXECUTE AS. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43966) (in query: error here ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5c6a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:24:36.702249 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope SELECT subtractDays([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:36.703284 [ 16207 ] {1851fd03-734b-4f9a-a20a-4b66cab77986} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 2 (error): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE, EXECUTE AS query, EXECUTE AS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5c6a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:36.865389 [ 16233 ] {71358482-a438-428a-85ca-49bf6f692f52} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope SELECT subtractHours([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1273, line 1276) (in query: SELECT subtractHours([NULL], [NULL], [NULL]);) 2025.11.13 09:24:36.891211 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope SELECT subtractHours([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:36.959095 [ 16233 ] {cbe82196-ce66-4fa5-b6e0-62393e27a3b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1274, line 1277) (in query: SELECT subtractInterval([NULL], [NULL], [NULL]);) 2025.11.13 09:24:36.978419 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:37.047330 [ 16233 ] {24fd1224-b594-4a5c-80ef-77743e99fcc8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMicroseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMicroseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1275, line 1278) (in query: SELECT subtractMicroseconds([NULL], [NULL], [NULL]);) 2025.11.13 09:24:37.159222 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMicroseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMicroseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:37.223870 [ 16233 ] {651ccd7e-da44-4c17-a97b-2062db0e2c9f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMilliseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMilliseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1276, line 1279) (in query: SELECT subtractMilliseconds([NULL], [NULL], [NULL]);) 2025.11.13 09:24:37.241284 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMilliseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMilliseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:37.277814 [ 16887 ] {ec70e1eb-21a5-432b-9824-b441a9af0321} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 534.16 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55834) (comment: 01125_generate_random_qoega.sql) (query 4, line 4) (in query: INSERT INTO mass_table_117 SELECT * FROM generateRandom('`dt` Date,`site_id` Int32,`site_key` String', 1, 10, 2) LIMIT 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:24:37.301718 [ 16233 ] {23f032fc-71d4-4cce-8152-bdc7a1da4944} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope SELECT subtractMinutes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1277, line 1280) (in query: SELECT subtractMinutes([NULL], [NULL], [NULL]);) 2025.11.13 09:24:37.319026 [ 16887 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 534.16 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:24:37.320211 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope SELECT subtractMinutes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:37.406357 [ 16233 ] {22d1fdda-6aa4-47a9-a295-318ec2ad993e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope SELECT subtractMonths([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1278, line 1281) (in query: SELECT subtractMonths([NULL], [NULL], [NULL]);) 2025.11.13 09:24:37.456327 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 534.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:37.458712 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 534.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:37.503811 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope SELECT subtractMonths([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:37.563325 [ 16233 ] {04efc64b-a507-412d-8797-1795ced6e012} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractNanoseconds. Must be a DateTime/DateTime64: In scope SELECT subtractNanoseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1279, line 1282) (in query: SELECT subtractNanoseconds([NULL], [NULL], [NULL]);) 2025.11.13 09:24:37.577619 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractNanoseconds. Must be a DateTime/DateTime64: In scope SELECT subtractNanoseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:37.715010 [ 16233 ] {b16b9d8c-3a54-4ba2-8cc5-13d94204c425} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope SELECT subtractQuarters([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1280, line 1283) (in query: SELECT subtractQuarters([NULL], [NULL], [NULL]);) 2025.11.13 09:24:37.731927 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope SELECT subtractQuarters([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:37.984208 [ 16233 ] {239a2c7a-7eeb-4aee-a4b0-ab2bd8a85ad7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope SELECT subtractSeconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1281, line 1284) (in query: SELECT subtractSeconds([NULL], [NULL], [NULL]);) 2025.11.13 09:24:38.000603 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope SELECT subtractSeconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:38.155828 [ 16233 ] {ba4adeb3-e1ef-48d1-8eb9-685d94e49769} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1282, line 1285) (in query: SELECT subtractTupleOfIntervals([NULL], [NULL], [NULL]);) 2025.11.13 09:24:38.168494 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:38.265222 [ 16233 ] {2f144be2-9adc-4d1a-9027-c0018048a90e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope SELECT subtractWeeks([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1283, line 1286) (in query: SELECT subtractWeeks([NULL], [NULL], [NULL]);) 2025.11.13 09:24:38.281374 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope SELECT subtractWeeks([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:38.351083 [ 16233 ] {51910d21-f540-485e-9e40-acca1726381a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope SELECT subtractYears([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1284, line 1287) (in query: SELECT subtractYears([NULL], [NULL], [NULL]);) 2025.11.13 09:24:38.363782 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope SELECT subtractYears([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:38.488333 [ 16233 ] {00af51a0-329b-4871-8d77-721f10f64978} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1285, line 1288) (in query: SELECT sum([NULL], [NULL], [NULL]);) 2025.11.13 09:24:38.503146 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:38.564739 [ 16233 ] {7bd152c0-b0dc-476d-96cf-967b63c67b53} executeQuery: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1286, line 1289) (in query: SELECT sumCount([NULL], [NULL], [NULL]);) 2025.11.13 09:24:38.578795 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:38.632965 [ 16233 ] {104d282d-74c7-46b2-9a8d-d069604184bd} executeQuery: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1287, line 1290) (in query: SELECT sumKahan([NULL], [NULL], [NULL]);) 2025.11.13 09:24:38.647973 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:38.767412 [ 16233 ] {252f7e9a-7b39-4de9-b3ea-ad1f51e38a18} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1288, line 1291) (in query: SELECT sumMapFiltered([NULL], [NULL], [NULL]);) 2025.11.13 09:24:38.783522 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:38.857980 [ 16233 ] {be64bdb5-36fd-473e-883f-8eecc25bff50} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1289, line 1292) (in query: SELECT sumMapFilteredWithOverflow([NULL], [NULL], [NULL]);) 2025.11.13 09:24:38.871702 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:38.934740 [ 16233 ] {fdaed04b-0c50-438b-b7da-11a778095f45} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1290, line 1293) (in query: SELECT sumMapWithOverflow([NULL], [NULL], [NULL]);) 2025.11.13 09:24:38.949733 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:39.009032 [ 16233 ] {40079202-c8c5-4a49-8708-50c618e26818} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1291, line 1294) (in query: SELECT sumMappedArrays([NULL], [NULL], [NULL]);) 2025.11.13 09:24:39.022321 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:39.079386 [ 16233 ] {bde5ecf5-0f37-4657-8036-6c6b2d63ed70} executeQuery: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1292, line 1295) (in query: SELECT sumWithOverflow([NULL], [NULL], [NULL]);) 2025.11.13 09:24:39.187786 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:39.312632 [ 16233 ] {f30f41c8-ef19-4dd2-a82e-f595960162dd} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1293, line 1296) (in query: SELECT svg([NULL], [NULL], [NULL]);) 2025.11.13 09:24:39.328484 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:39.399802 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 475.51 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:39.402676 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 475.51 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:39.413674 [ 16233 ] {46a2254a-1d78-4852-ad91-233cccbb2a86} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1294, line 1297) (in query: SELECT synonyms([NULL], [NULL], [NULL]);) 2025.11.13 09:24:39.509510 [ 16233 ] {} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.11.13 09:24:39.618152 [ 16233 ] {ec1d1879-b89a-4b2c-9eb4-782e83f189d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1295, line 1298) (in query: SELECT tan([NULL], [NULL], [NULL]);) 2025.11.13 09:24:39.792792 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:39.960674 [ 16233 ] {860961a6-a6b6-40c6-85c1-8b0f2d9bbda2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1296, line 1299) (in query: SELECT tanh([NULL], [NULL], [NULL]);) 2025.11.13 09:24:39.981439 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:40.121657 [ 16233 ] {48f782b8-f9ff-4be5-bbf0-6d172042ffa6} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1297, line 1300) (in query: SELECT tcpPort([NULL], [NULL], [NULL]);) 2025.11.13 09:24:40.135685 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:40.213465 [ 16233 ] {d3e8848f-8dab-4229-8cec-2dd20f33b33e} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1298, line 1301) (in query: SELECT test_function([NULL], [NULL], [NULL]);) 2025.11.13 09:24:40.228385 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:40.286653 [ 17376 ] {9107719f-98fd-4531-acd9-e9ed08fac76d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55890) (comment: 00002_system_numbers.sql) (query 8, line 9) (in query: select x from system.numbers limit 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.295801 [ 17376 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.426724 [ 17376 ] {2e5ff55f-bb39-4003-b441-23f842cf3882} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x, number FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55890) (comment: 00002_system_numbers.sql) (query 9, line 10) (in query: SELECT x, number FROM system.numbers LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.451538 [ 16233 ] {c4b03b5b-a2df-41ff-9563-14ebbb98f474} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1299, line 1302) (in query: SELECT tgamma([NULL], [NULL], [NULL]);) 2025.11.13 09:24:40.472755 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:40.530117 [ 17376 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x, number FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.533462 [ 16233 ] {3062ed68-0052-410d-bc1f-6a304cb55fe4} executeQuery: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1300, line 1303) (in query: SELECT theilsU([NULL], [NULL], [NULL]);) 2025.11.13 09:24:40.551227 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:40.575212 [ 17376 ] {cbfcfc61-c1c8-47ed-9c0d-c695c1e52dbe} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'system.number' in scope SELECT * FROM system.number LIMIT 1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55890) (comment: 00002_system_numbers.sql) (query 10, line 11) (in query: SELECT * FROM system.number LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.584237 [ 17376 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'system.number' in scope SELECT * FROM system.number LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.627944 [ 17376 ] {63e89682-6e2b-4cc2-a896-01d85541267f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'system' in scope SELECT * FROM system LIMIT 1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55890) (comment: 00002_system_numbers.sql) (query 11, line 12) (in query: SELECT * FROM system LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.640858 [ 17376 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'system' in scope SELECT * FROM system LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.681230 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 500.73 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:40.683832 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 500.73 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:40.695058 [ 17376 ] {49917c83-bc6c-4cb3-a1cc-07b54da213cb} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT * FROM numbers LIMIT 1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55890) (comment: 00002_system_numbers.sql) (query 12, line 13) (in query: SELECT * FROM numbers LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.704736 [ 17376 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT * FROM numbers LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.726932 [ 16233 ] {38ec227f-03dd-4ebc-88a3-fd950cdad9c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1301, line 1304) (in query: SELECT throwIf([NULL], [NULL], [NULL]);) 2025.11.13 09:24:40.741775 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:40.754243 [ 17376 ] {3881732a-6445-40c9-99b9-56342406a461} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `sys.number` in scope SELECT sys.number FROM system.numbers AS sys_num LIMIT 1. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55890) (comment: 00002_system_numbers.sql) (query 13, line 14) (in query: SELECT sys.number FROM system.numbers AS sys_num LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.763233 [ 17376 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `sys.number` in scope SELECT sys.number FROM system.numbers AS sys_num LIMIT 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:24:40.803097 [ 16233 ] {6fe13565-2166-4b33-9122-d73aa9e3ae91} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1302, line 1305) (in query: SELECT tid([NULL], [NULL], [NULL]);) 2025.11.13 09:24:40.818731 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:40.880594 [ 16233 ] {6d5e1e31-43b9-454d-abca-336d0d89e3f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1303, line 1306) (in query: SELECT timeDiff([NULL], [NULL], [NULL]);) 2025.11.13 09:24:40.894456 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:40.949030 [ 16233 ] {d7ef2bf4-5495-4e4c-aef8-6177e00a47b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 3, should be 1 or 2: In scope SELECT timeSlot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1304, line 1307) (in query: SELECT timeSlot([NULL], [NULL], [NULL]);) 2025.11.13 09:24:40.962203 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 3, should be 1 or 2: In scope SELECT timeSlot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:41.020272 [ 16233 ] {8f4520d0-56f8-4d25-a0ee-9c6fc592537b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function timeSlots. Must be DateTime or DateTime64.: In scope SELECT timeSlots([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1305, line 1308) (in query: SELECT timeSlots([NULL], [NULL], [NULL]);) 2025.11.13 09:24:41.078115 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function timeSlots. Must be DateTime or DateTime64.: In scope SELECT timeSlots([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:41.146891 [ 16233 ] {870c1521-9015-4c07-b8a5-87ae17d6152c} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1306, line 1309) (in query: SELECT timeZone([NULL], [NULL], [NULL]);) 2025.11.13 09:24:41.165236 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:41.280385 [ 16233 ] {b36ae377-7a87-4032-b671-8bbca0025956} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1307, line 1310) (in query: SELECT timeZoneOf([NULL], [NULL], [NULL]);) 2025.11.13 09:24:41.297732 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:41.365743 [ 16233 ] {134a154b-09e3-45b8-9e37-c48dfe818b05} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timeZoneOffset([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1308, line 1311) (in query: SELECT timeZoneOffset([NULL], [NULL], [NULL]);) 2025.11.13 09:24:41.382822 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timeZoneOffset([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:41.517391 [ 16233 ] {f1c9eb61-90ab-4f3c-9f08-0ac531988f9b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT time_bucket([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1309, line 1312) (in query: SELECT time_bucket([NULL], [NULL], [NULL]);) 2025.11.13 09:24:41.533846 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT time_bucket([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:41.591819 [ 16233 ] {14252414-b4e6-4a84-9828-cc6928f699e6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1310, line 1313) (in query: SELECT timestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:24:41.607623 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:41.723808 [ 16233 ] {a3856e8b-5e48-4150-b8f3-816d1aa0fc14} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1311, line 1314) (in query: SELECT timestampDiff([NULL], [NULL], [NULL]);) 2025.11.13 09:24:41.737451 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:41.794311 [ 16233 ] {c965a013-6307-4cf7-89c2-dc24c58439c0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1312, line 1315) (in query: SELECT timestamp_diff([NULL], [NULL], [NULL]);) 2025.11.13 09:24:41.807943 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:41.862726 [ 16233 ] {54f008ad-f282-4e0a-95bf-4091c84e8ddd} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1313, line 1316) (in query: SELECT timezone([NULL], [NULL], [NULL]);) 2025.11.13 09:24:41.876401 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:41.932274 [ 16233 ] {05972ebd-ca8f-4601-af65-4c08b21cc859} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1314, line 1317) (in query: SELECT timezoneOf([NULL], [NULL], [NULL]);) 2025.11.13 09:24:41.997446 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:42.133285 [ 16233 ] {7dc5f1de-52f4-42b9-a4ee-3c098f1b75b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timezoneOffset([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1315, line 1318) (in query: SELECT timezoneOffset([NULL], [NULL], [NULL]);) 2025.11.13 09:24:42.147173 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timezoneOffset([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:42.204963 [ 16233 ] {cc65e88e-0921-4b34-9b06-a13be08ea3c8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toBFloat16'. Expected 1 argument, got 3 arguments: In scope SELECT toBFloat16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1316, line 1319) (in query: SELECT toBFloat16([NULL], [NULL], [NULL]);) 2025.11.13 09:24:42.218574 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toBFloat16'. Expected 1 argument, got 3 arguments: In scope SELECT toBFloat16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:42.334374 [ 16233 ] {e86d60c5-9c34-4ed2-af72-7bd4b92db691} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1317, line 1320) (in query: SELECT toBFloat16OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:42.348652 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:42.403190 [ 16233 ] {eaf52636-a461-4a9c-8e00-04dee8f41826} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1318, line 1321) (in query: SELECT toBFloat16OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:42.463578 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBFloat16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toBFloat16OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:42.536129 [ 16233 ] {cd99d6cf-3067-4180-805b-e4d6765734b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1319, line 1322) (in query: SELECT toBool([NULL], [NULL], [NULL]);) 2025.11.13 09:24:42.550649 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:42.609834 [ 16233 ] {dc4cd4be-d417-46ec-add7-a800d79465cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1320, line 1323) (in query: SELECT toColumnTypeName([NULL], [NULL], [NULL]);) 2025.11.13 09:24:42.621959 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.48 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:42.624342 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.48 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:42.678168 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:42.757690 [ 16233 ] {def93f1a-aa14-4941-a52b-a361bc751fea} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1321, line 1324) (in query: SELECT toDate([NULL], [NULL], [NULL]);) 2025.11.13 09:24:42.877146 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:42.989338 [ 16233 ] {ad01ecb4-0fb3-405c-831d-4befff73b04a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1322, line 1325) (in query: SELECT toDate32([NULL], [NULL], [NULL]);) 2025.11.13 09:24:43.006869 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:43.070972 [ 16233 ] {4891235a-bfc5-4163-b748-1463c3a75769} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1323, line 1326) (in query: SELECT toDate32OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:43.106554 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:43.157533 [ 16233 ] {c508c174-64e2-4274-a92e-e0c86103409e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1324, line 1327) (in query: SELECT toDate32OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:43.267798 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:43.341477 [ 16233 ] {1debd096-6c5f-4aa2-8d38-8aa774b52497} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1325, line 1328) (in query: SELECT toDate32OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:43.356419 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:43.473638 [ 16233 ] {7cb2f00f-455e-4bd7-b6ea-0153fb9fb303} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1326, line 1329) (in query: SELECT toDateOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:43.547020 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:43.608032 [ 16233 ] {8bfa85f5-e1c9-410a-80c9-85a22db30a0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1327, line 1330) (in query: SELECT toDateOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:43.622404 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:43.734860 [ 16233 ] {69e3d199-2189-4f2f-9055-b7acae055559} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1328, line 1331) (in query: SELECT toDateOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:43.749049 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:43.843315 [ 16233 ] {d7313b4a-8786-45f3-9831-5d7c012f9a36} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1329, line 1332) (in query: SELECT toDateTime([NULL], [NULL], [NULL]);) 2025.11.13 09:24:43.874890 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:43.964411 [ 16233 ] {13a4e85d-ab7a-4f16-adb4-453784283d4d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateTime32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1330, line 1333) (in query: SELECT toDateTime32([NULL], [NULL], [NULL]);) 2025.11.13 09:24:43.978691 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateTime32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:44.031849 [ 16233 ] {b7324a0d-78bc-4f2b-84da-ebc70748ce49} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1331, line 1334) (in query: SELECT toDateTime64([NULL], [NULL], [NULL]);) 2025.11.13 09:24:44.045376 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:44.268634 [ 16233 ] {a0498dd6-285c-4372-a042-ec2e51e453b0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1332, line 1335) (in query: SELECT toDateTime64OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:44.328034 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:44.386354 [ 16233 ] {d543e3d3-4a07-4985-b40a-6c40c55ab1bd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1333, line 1336) (in query: SELECT toDateTime64OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:44.388270 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.28 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:44.389652 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.28 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:44.402295 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:44.436298 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.35 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:44.438408 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_111_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.35 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:44.498495 [ 16233 ] {96645ab0-2648-41e4-8a00-890330f6175a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1334, line 1337) (in query: SELECT toDateTime64OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:44.513272 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:44.655325 [ 16233 ] {b29f70f7-cb38-47f5-bbaa-c33c2789f822} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT toDateTimeOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1335, line 1338) (in query: SELECT toDateTimeOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:44.669407 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT toDateTimeOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:44.745226 [ 16233 ] {736f32fc-130d-4d52-9241-f04cf4e117b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1336, line 1339) (in query: SELECT toDateTimeOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:44.762984 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:44.831519 [ 16233 ] {de53decd-9a15-4a46-9464-04d4ed9514e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1337, line 1340) (in query: SELECT toDateTimeOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:44.850295 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:45.012266 [ 16233 ] {d4b1ac57-d10c-4126-9171-d14fead5eb3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1338, line 1341) (in query: SELECT toDayOfMonth([NULL], [NULL], [NULL]);) 2025.11.13 09:24:45.103608 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:45.169557 [ 16233 ] {4fe55bb8-1f8b-4e51-aa4d-97a443b36d5a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1339, line 1342) (in query: SELECT toDayOfWeek([NULL], [NULL], [NULL]);) 2025.11.13 09:24:45.183722 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:45.238330 [ 16233 ] {76d82073-717b-4424-9aee-cfe1903716f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1340, line 1343) (in query: SELECT toDayOfYear([NULL], [NULL], [NULL]);) 2025.11.13 09:24:45.316609 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:45.424298 [ 16233 ] {8ba4c8b0-b40d-46e1-81d1-d8c0e2f8f6e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT toDaysSinceYearZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1341, line 1344) (in query: SELECT toDaysSinceYearZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:45.440079 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT toDaysSinceYearZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:45.552616 [ 16233 ] {3a9598f3-30f6-47bf-82e5-e473eefddb4a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1342, line 1345) (in query: SELECT toDecimal128([NULL], [NULL], [NULL]);) 2025.11.13 09:24:45.567325 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:45.635894 [ 16233 ] {8d1a7ef3-2a33-49c8-8eb1-f66a27ebaaf3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal128OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1343, line 1346) (in query: SELECT toDecimal128OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:45.648713 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal128OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:45.776922 [ 5803 ] {6ab896e3-cc71-4b6c-8bcd-ac297a65d845::all_1_5_3_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 446.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a4cd316 31. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e73d0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:45.791374 [ 5803 ] {c1f48538-a18e-46ce-994a-03b82e5eb38f} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 446.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55734) (comment: 02404_lightweight_delete_vertical_merge.sql) (query 36, line 165) (in query: -- optimize table to merge 2 parts together, both of them have LWD rows -- physically delete the rows OPTIMIZE TABLE lwd_test FINAL SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a4cd316 31. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e73d0 2025.11.13 09:24:45.829191 [ 5803 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 446.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:106: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a4cd316 31. ./build_docker/./src/Storages/StorageMergeTree.cpp:1683: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a4e73d0 2025.11.13 09:24:45.877449 [ 16233 ] {77653e99-9313-4733-909c-609ecda59019} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1344, line 1347) (in query: SELECT toDecimal128OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:45.902139 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:45.976047 [ 16233 ] {18612da0-a755-4582-83ec-76ea4efdb2ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1345, line 1348) (in query: SELECT toDecimal128OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:45.997431 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:46.050333 [ 16233 ] {4ca0fd6c-a222-425f-b551-388daa4e16e0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1346, line 1349) (in query: SELECT toDecimal256([NULL], [NULL], [NULL]);) 2025.11.13 09:24:46.069780 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:46.126633 [ 16233 ] {45e1b419-bdc0-4fac-8976-c890a1b6dd51} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal256OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1347, line 1350) (in query: SELECT toDecimal256OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:46.146842 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal256OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:46.243059 [ 16233 ] {30217750-3db9-4fe1-8f45-9125d7d9bcc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1348, line 1351) (in query: SELECT toDecimal256OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:46.259022 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:46.405460 [ 16233 ] {4681a243-c8ed-4e3b-9a06-1cf9955a1b7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1349, line 1352) (in query: SELECT toDecimal256OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:46.419718 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:46.475978 [ 16233 ] {9b921ec3-f916-424c-a860-359b6fede618} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1350, line 1353) (in query: SELECT toDecimal32([NULL], [NULL], [NULL]);) 2025.11.13 09:24:46.494964 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:46.641244 [ 16233 ] {1aaa9c6c-5506-44cf-8033-f99713ea6f9c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1351, line 1354) (in query: SELECT toDecimal32OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:46.642340 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 502.12 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:46.645010 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 502.12 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:46.659657 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:46.807908 [ 16233 ] {66cab894-9a1f-4d71-b715-a15c4dd23d68} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1352, line 1355) (in query: SELECT toDecimal32OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:46.827584 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:46.988544 [ 16233 ] {80d45315-9a60-427e-affd-e74ddfbede99} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1353, line 1356) (in query: SELECT toDecimal32OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:47.003887 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:47.073040 [ 16233 ] {6134a570-ef7e-450c-a0fb-1e0003365d13} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1354, line 1357) (in query: SELECT toDecimal64([NULL], [NULL], [NULL]);) 2025.11.13 09:24:47.088724 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:47.147650 [ 16233 ] {456e800d-b5db-48df-8222-7fae55dc595d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1355, line 1358) (in query: SELECT toDecimal64OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:47.161865 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:47.271859 [ 16233 ] {e5858fdd-15f9-40e8-808d-84154fd99eb1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1356, line 1359) (in query: SELECT toDecimal64OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:47.321111 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:47.392205 [ 3736 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_134_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 502.07 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_128_10/initial_query_id.bin (position: 24616, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 1b4b39c77873ce7eca3dd6a67cfb4fd88218600000bc920400): (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_128_10/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 15. DB::ReadBuffer::next() @ 0x0000000008ef7cef 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:47.394697 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_134_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 502.07 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_128_10/initial_query_id.bin (position: 24616, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 1b4b39c77873ce7eca3dd6a67cfb4fd88218600000bc920400): (while reading column initial_query_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_128_10/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 15. DB::ReadBuffer::next() @ 0x0000000008ef7cef 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:47.475088 [ 16233 ] {46afdea3-eabd-48a2-9eac-fb48f129b2ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1357, line 1360) (in query: SELECT toDecimal64OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:47.491081 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:47.562886 [ 16233 ] {962f1332-4dd9-4420-b613-8e9c5f801ffb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1358, line 1361) (in query: SELECT toDecimalString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:47.684753 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:47.745493 [ 16233 ] {407dbda1-cbaf-4b3f-80d2-f78a86375311} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1359, line 1362) (in query: SELECT toFixedString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:47.766191 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:47.828763 [ 16233 ] {5974a26b-47c2-4587-8ece-563e8a04ccbe} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1360, line 1363) (in query: SELECT toFloat32([NULL], [NULL], [NULL]);) 2025.11.13 09:24:47.843735 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:47.898633 [ 3739 ] {34ed885f-0374-4b2a-a18b-f9a13016aca0::202511_1_31_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.11 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column user): (while reading from part /var/lib/clickhouse/store/34e/34ed885f-0374-4b2a-a18b-f9a13016aca0/202511_1_26_5/ in table system.session_log (34ed885f-0374-4b2a-a18b-f9a13016aca0) located on disk default of type local, from mark 0 with max_rows_to_read = 8280): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:138: DB::SerializationNullable::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c7fac 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:47.950942 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {34ed885f-0374-4b2a-a18b-f9a13016aca0::202511_1_31_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.11 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column user): (while reading from part /var/lib/clickhouse/store/34e/34ed885f-0374-4b2a-a18b-f9a13016aca0/202511_1_26_5/ in table system.session_log (34ed885f-0374-4b2a-a18b-f9a13016aca0) located on disk default of type local, from mark 0 with max_rows_to_read = 8280): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:138: DB::SerializationNullable::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c7fac 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:47.985949 [ 16233 ] {a4a68e3d-bad3-4f10-8d69-a0a2b8088e7c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1361, line 1364) (in query: SELECT toFloat32OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:48.034506 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:48.214680 [ 16233 ] {6b9ed6ae-e20d-4dbf-b566-899de9f7a689} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1362, line 1365) (in query: SELECT toFloat32OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:48.229501 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:48.362736 [ 16233 ] {93698ac3-7744-4d83-a4df-0de76ba8aa04} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1363, line 1366) (in query: SELECT toFloat32OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:48.365333 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:48.367824 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:48.381636 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:48.439971 [ 16233 ] {c80e2c29-4e1d-4bae-a03e-96ac83055ed6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1364, line 1367) (in query: SELECT toFloat64([NULL], [NULL], [NULL]);) 2025.11.13 09:24:48.454922 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:48.563589 [ 16233 ] {09465a0c-8747-466b-9510-e6ca505ea3a1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1365, line 1368) (in query: SELECT toFloat64OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:48.578189 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:48.636874 [ 16233 ] {6f68acdb-780f-4ffd-9ce4-a0f3ea2167cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1366, line 1369) (in query: SELECT toFloat64OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:48.650937 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:48.723848 [ 16233 ] {c29a1198-7e28-418c-8be9-a132e724f35a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1367, line 1370) (in query: SELECT toFloat64OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:48.737381 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:48.799844 [ 3731 ] {34ed885f-0374-4b2a-a18b-f9a13016aca0::202511_1_31_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:48.802058 [ 16233 ] {c9d986b0-db52-41c0-8c1e-3b2b7385815e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1368, line 1371) (in query: SELECT toHour([NULL], [NULL], [NULL]);) 2025.11.13 09:24:48.803128 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {34ed885f-0374-4b2a-a18b-f9a13016aca0::202511_1_31_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:48.817808 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:48.884771 [ 16233 ] {1edc7018-8234-4905-ae1c-0f14d0a35433} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1369, line 1372) (in query: SELECT toIPv4([NULL], [NULL], [NULL]);) 2025.11.13 09:24:49.046836 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:49.088320 [ 3726 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_134_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.16 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column parent_ids): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_128_10/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:141: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5afa72 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:49.091660 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_134_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.16 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column parent_ids): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_128_10/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:141: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5afa72 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:49.183346 [ 16233 ] {00b48e8f-d212-4d60-9fb4-5b44cef7f34a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1370, line 1373) (in query: SELECT toIPv4OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:49.202430 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:49.271936 [ 16233 ] {6bc2330f-1634-4c4a-a3aa-b1da8974ed2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1371, line 1374) (in query: SELECT toIPv4OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:49.387139 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:49.482746 [ 16233 ] {0bc1ec7c-2dca-4133-9535-969099bc440d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1372, line 1375) (in query: SELECT toIPv4OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:49.551674 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:49.595438 [ 19621 ] {ed7ba551-1fce-422c-bbe7-380f4f5cff98} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45168) (comment: 00124_shard_distributed_with_many_replicas.sql) (query 9, line 13) (in query: SELECT * FROM (SELECT id, event_date, priority, description FROM remote('127.0.0.{2|3}', currentDatabase(), report)) ORDER BY id ASC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./build_docker/./src/Client/HedgedConnections.cpp:407: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003ab395af 15. ./build_docker/./src/Client/HedgedConnections.cpp:386: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003ab36893 16. ./build_docker/./src/Client/HedgedConnections.cpp:360: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab38dab 17. ./build_docker/./src/Client/HedgedConnections.cpp:342: DB::HedgedConnections::receivePacket() @ 0x000000003ab38821 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:503: DB::RemoteQueryExecutor::read() @ 0x000000002f27d2b9 19. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:479: DB::RemoteQueryExecutor::readBlock() @ 0x000000002f27c580 20. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:100: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038f263c7 21. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:160: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038f2a314 22. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000266ee609 23. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ecab9 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 25. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5354: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7c72 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 2025.11.13 09:24:49.617577 [ 19621 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./build_docker/./src/Client/HedgedConnections.cpp:407: DB::HedgedConnections::resumePacketReceiver(DB::HedgedConnections::ReplicaLocation const&) @ 0x000000003ab395af 15. ./build_docker/./src/Client/HedgedConnections.cpp:386: DB::HedgedConnections::getReadyReplicaLocation(std::function) @ 0x000000003ab36893 16. ./build_docker/./src/Client/HedgedConnections.cpp:360: DB::HedgedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab38dab 17. ./build_docker/./src/Client/HedgedConnections.cpp:342: DB::HedgedConnections::receivePacket() @ 0x000000003ab38821 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:503: DB::RemoteQueryExecutor::read() @ 0x000000002f27d2b9 19. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:479: DB::RemoteQueryExecutor::readBlock() @ 0x000000002f27c580 20. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:100: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038f263c7 21. ./build_docker/./src/Storages/getStructureOfRemoteTable.cpp:160: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000038f2a314 22. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x00000000266ee609 23. ./build_docker/./src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000266ecab9 24. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 25. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 29. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3871: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003041426b 30. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5354: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7c72 31. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 2025.11.13 09:24:49.618716 [ 16233 ] {7f167d90-c7ac-4152-a8ce-86b0391d673c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv6([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1373, line 1376) (in query: SELECT toIPv6([NULL], [NULL], [NULL]);) 2025.11.13 09:24:49.637699 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv6([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:49.704160 [ 16198 ] {0e2902b2-e195-4787-9eac-74111b883d4f} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:50116). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7e6b 7. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 8. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:49.711544 [ 16198 ] {0e2902b2-e195-4787-9eac-74111b883d4f} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:50116). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50116) (comment: 00124_shard_distributed_with_many_replicas.sql) (query 9, line 13) (in query: DESC TABLE test_3.report), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7e6b 7. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 8. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:24:49.725987 [ 16198 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:50116). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef7e6b 7. ./build_docker/./src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed482d 8. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:24:49.763250 [ 16233 ] {e05a7b40-144e-4484-8667-c8a8cf47a8e2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1374, line 1377) (in query: SELECT toIPv6OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:49.782385 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:49.844847 [ 16233 ] {41cd1a43-eb6e-4777-922c-4545b7a6be0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1375, line 1378) (in query: SELECT toIPv6OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:49.857911 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:49.913842 [ 16233 ] {53d6b185-9af9-46ec-bdfc-11fffd6e90b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1376, line 1379) (in query: SELECT toIPv6OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:49.928255 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:49.983254 [ 16233 ] {19b17b43-aed3-4045-9bbe-8f8cf53392db} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOWeek([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1377, line 1380) (in query: SELECT toISOWeek([NULL], [NULL], [NULL]);) 2025.11.13 09:24:50.068131 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOWeek([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:50.197769 [ 16233 ] {9eb0c969-b3f8-4a84-b229-a80ca8b8754b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1378, line 1381) (in query: SELECT toISOYear([NULL], [NULL], [NULL]);) 2025.11.13 09:24:50.212752 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:50.277149 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 468.29 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:50.279620 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 468.29 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:50.312715 [ 3738 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_134_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 468.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:50.319091 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_134_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 468.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:50.346973 [ 16233 ] {27463739-438d-40fe-86b9-27944f93deda} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1379, line 1382) (in query: SELECT toInt128([NULL], [NULL], [NULL]);) 2025.11.13 09:24:50.365892 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:50.553528 [ 16233 ] {9fe23830-8b74-446a-b85f-067691d19743} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1380, line 1383) (in query: SELECT toInt128OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:50.569910 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:50.716069 [ 16233 ] {e469d697-cf78-4d27-85e7-ffaf66e6f8c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1381, line 1384) (in query: SELECT toInt128OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:50.732379 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:50.795216 [ 16233 ] {416640e3-1808-4aa5-a536-7a44aadf6930} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1382, line 1385) (in query: SELECT toInt128OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:50.815172 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:50.939044 [ 16233 ] {341420e4-5502-41d8-a6bc-00112697bc24} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1383, line 1386) (in query: SELECT toInt16([NULL], [NULL], [NULL]);) 2025.11.13 09:24:50.960660 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:51.074943 [ 16233 ] {83046f81-2545-4061-b365-1f5bf56a7e47} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1384, line 1387) (in query: SELECT toInt16OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:51.090450 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:51.186883 [ 16233 ] {248222db-7756-4c9d-8fe7-a94556c5726b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1385, line 1388) (in query: SELECT toInt16OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:51.201520 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:51.333566 [ 16233 ] {cdf60a23-69eb-4b7f-84d4-ba1f849b706a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1386, line 1389) (in query: SELECT toInt16OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:51.350004 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:51.408887 [ 16233 ] {70991a5c-7087-46f4-acf3-35e40ae3c104} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1387, line 1390) (in query: SELECT toInt256([NULL], [NULL], [NULL]);) 2025.11.13 09:24:51.424974 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:51.520683 [ 16233 ] {794bc0f6-d4c8-4e31-925a-08e3efff5208} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1388, line 1391) (in query: SELECT toInt256OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:51.535109 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:51.596407 [ 16233 ] {256c545a-4d2b-4d78-8b3d-17d978a3242e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1389, line 1392) (in query: SELECT toInt256OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:51.613401 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:51.642926 [ 3735 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_134_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 466.71 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (avg_value_size_hint = 14.3172607421875, avg_chars_size = 7.580712890625, limit = 8192): (while reading column step_uniq_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_128_10/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:51.688166 [ 16233 ] {9f26fa2d-4d48-4ba7-aa50-7e0c2248291d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1390, line 1393) (in query: SELECT toInt256OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:51.712839 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:51.720705 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_134_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 466.71 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (avg_value_size_hint = 14.3172607421875, avg_chars_size = 7.580712890625, limit = 8192): (while reading column step_uniq_id): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_128_10/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:51.975974 [ 16233 ] {8ada5608-2d5b-4d97-8045-335d85aa3cd3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1391, line 1394) (in query: SELECT toInt32([NULL], [NULL], [NULL]);) 2025.11.13 09:24:52.057888 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:52.195657 [ 16233 ] {7f6dce02-e7d8-484a-bc1b-fd0d30180e7c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1392, line 1395) (in query: SELECT toInt32OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:52.206455 [ 19620 ] {4f12596b-3090-4f88-9893-27c17f7ac876} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=868). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45196) (comment: 01064_arrayROCAUC.sql) (query 13, line 13) (in query: select arrayROCAUC(cast([-10, -40, -35, -80] as Array(Int64)), [0, 0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:52.245954 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:52.281345 [ 19620 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=868). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:52.307364 [ 16233 ] {57785cf4-66d3-4b34-8bb3-f188f6e12f8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1393, line 1396) (in query: SELECT toInt32OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:52.325169 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:52.382857 [ 16233 ] {c8306aca-8fb5-4810-999a-745ef11da3c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1394, line 1397) (in query: SELECT toInt32OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:52.399407 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:52.457440 [ 16233 ] {8b85e956-f4bd-4cc9-977a-58596d4e81e2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1395, line 1398) (in query: SELECT toInt64([NULL], [NULL], [NULL]);) 2025.11.13 09:24:52.472788 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:52.526329 [ 16233 ] {dbb48b87-bae8-47d8-8673-3721aecfe6ec} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1396, line 1399) (in query: SELECT toInt64OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:52.593667 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:52.651289 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 542.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:52.652468 [ 16233 ] {8852d7f2-62d1-4c1a-80c4-613c28f6c2af} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1397, line 1400) (in query: SELECT toInt64OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:52.652561 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 542.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:52.668309 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:52.812382 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 542.15 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:52.815905 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 542.15 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:52.847121 [ 16233 ] {48ea2b81-4c41-44c8-b5e2-fdf940a91d01} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1398, line 1401) (in query: SELECT toInt64OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:52.865220 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:53.005823 [ 16233 ] {d54ed85a-500b-48db-beb5-62c2c87c76d9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1399, line 1402) (in query: SELECT toInt8([NULL], [NULL], [NULL]);) 2025.11.13 09:24:53.027446 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:53.100630 [ 16233 ] {d7a03b7b-d2e5-4bb6-b2ba-5a4cfef95b80} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1400, line 1403) (in query: SELECT toInt8OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:24:53.110382 [ 3456 ] {} RefreshTask: test_2vd3sk69.a: Refresh failed (attempt 0/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_2vd3sk69.src' in scope SELECT x * 2 AS x FROM test_2vd3sk69.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdd406 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:564: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x000000003874a06b 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:665: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a990ed6 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:558: DB::RefreshTask::refreshTask() @ 0x000000003a981140 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:144: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a996b7f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:53.115621 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:53.176579 [ 16233 ] {7c7eebe6-1569-48e1-ad39-3879d672a3cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1401, line 1404) (in query: SELECT toInt8OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:53.191681 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:53.311227 [ 16233 ] {5daa1375-f840-4a75-9429-5b9839d81c43} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1402, line 1405) (in query: SELECT toInt8OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:24:53.324622 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:53.451582 [ 16233 ] {abcc1266-f173-4e17-aaeb-ea0d4e16b991} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1403, line 1406) (in query: SELECT toIntervalDay([NULL], [NULL], [NULL]);) 2025.11.13 09:24:53.467678 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:53.518834 [ 16198 ] {6a6a2cb9-70f0-4675-af5b-f979341e8f38} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55336) (comment: 02024_create_dictionary_with_comment.sql) (query 8, line 33) (in query: DROP DICTIONARY IF EXISTS 2024_dictionary_with_comment;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:24:53.530682 [ 16233 ] {b9ce09b1-773b-454c-a06e-0534127f33dc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1404, line 1407) (in query: SELECT toIntervalHour([NULL], [NULL], [NULL]);) 2025.11.13 09:24:53.533044 [ 16198 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:24:53.545928 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:53.654681 [ 16233 ] {7e8f16ee-f6e6-4522-a74a-0ea823e2a32c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMicrosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1405, line 1408) (in query: SELECT toIntervalMicrosecond([NULL], [NULL], [NULL]);) 2025.11.13 09:24:53.672315 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMicrosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:53.763277 [ 16233 ] {e0e5f436-c6a9-4e09-a22f-8177c8e5c683} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1406, line 1409) (in query: SELECT toIntervalMillisecond([NULL], [NULL], [NULL]);) 2025.11.13 09:24:53.789680 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:53.812730 [ 19620 ] {e5c91ab7-48c4-4b7a-880f-4e519d17fbf0} executeQuery: Code: 730. DB::Exception: Refresh failed: Code: 60. DB::Exception: Unknown table expression identifier 'test_2vd3sk69.src' in scope SELECT x * 2 AS x FROM test_2vd3sk69.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdd406 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:564: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x000000003874a06b 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:665: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a990ed6 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:558: DB::RefreshTask::refreshTask() @ 0x000000003a981140 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:144: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a996b7f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)). (REFRESH_FAILED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55342) (comment: 02932_refreshable_materialized_views_1.sh) (query 1, line 1) (in query: system wait view a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:362: DB::RefreshTask::wait()::$_0::operator()() const @ 0x000000003a97ea08 5. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:372: DB::RefreshTask::wait() @ 0x000000003a97d3d8 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:725: DB::InterpreterSystemQuery::execute() @ 0x00000000338e4905 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:53.822025 [ 19620 ] {} TCPHandler: Code: 730. DB::Exception: Refresh failed: Code: 60. DB::Exception: Unknown table expression identifier 'test_2vd3sk69.src' in scope SELECT x * 2 AS x FROM test_2vd3sk69.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdd406 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:564: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x000000003874a06b 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:665: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x000000003a990ed6 14. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:558: DB::RefreshTask::refreshTask() @ 0x000000003a981140 15. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:144: void std::__function::__policy_invoker::__call_impl[abi:ne190107], DB::ASTRefreshStrategy const&, bool, bool, bool, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003a996b7f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 17. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)). (REFRESH_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:362: DB::RefreshTask::wait()::$_0::operator()() const @ 0x000000003a97ea08 5. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:372: DB::RefreshTask::wait() @ 0x000000003a97d3d8 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:725: DB::InterpreterSystemQuery::execute() @ 0x00000000338e4905 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:24:53.854704 [ 16233 ] {d43292d0-59ab-4f8e-b8e3-c535043cfd1a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1407, line 1410) (in query: SELECT toIntervalMinute([NULL], [NULL], [NULL]);) 2025.11.13 09:24:53.872895 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:54.037184 [ 16233 ] {7ac86b51-5172-4e28-a79c-8a3140677fb9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1408, line 1411) (in query: SELECT toIntervalMonth([NULL], [NULL], [NULL]);) 2025.11.13 09:24:54.051456 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:54.106195 [ 16233 ] {0b580875-8c2f-4949-a61a-2a3f6c649e5d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalNanosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1409, line 1412) (in query: SELECT toIntervalNanosecond([NULL], [NULL], [NULL]);) 2025.11.13 09:24:54.124129 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalNanosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:54.203467 [ 16233 ] {a27abc7a-b89b-4aba-9ea9-156effd1d348} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1410, line 1413) (in query: SELECT toIntervalQuarter([NULL], [NULL], [NULL]);) 2025.11.13 09:24:54.219972 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:54.316768 [ 16233 ] {9fbdc361-5490-4103-80bc-24a1ebd38871} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1411, line 1414) (in query: SELECT toIntervalSecond([NULL], [NULL], [NULL]);) 2025.11.13 09:24:54.334050 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:54.400166 [ 16233 ] {357a16f0-b342-4bce-b8fe-d009310de14b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalWeek([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1412, line 1415) (in query: SELECT toIntervalWeek([NULL], [NULL], [NULL]);) 2025.11.13 09:24:54.432079 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalWeek([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:54.518505 [ 16233 ] {2380360a-1450-4769-a854-3ec443a93628} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1413, line 1416) (in query: SELECT toIntervalYear([NULL], [NULL], [NULL]);) 2025.11.13 09:24:54.536337 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:54.599405 [ 16233 ] {aadffe8b-389b-4a04-ab60-bdaa27264f93} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1414, line 1417) (in query: SELECT toJSONString([NULL], [NULL], [NULL]);) 2025.11.13 09:24:54.690863 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:54.750746 [ 16233 ] {82c2b6f9-6956-41da-8d15-871ac10d7204} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toLastDayOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1415, line 1418) (in query: SELECT toLastDayOfMonth([NULL], [NULL], [NULL]);) 2025.11.13 09:24:54.764602 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toLastDayOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:54.850629 [ 16233 ] {bcab8129-3246-428a-a409-addb72620e87} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1416, line 1419) (in query: SELECT toLastDayOfWeek([NULL], [NULL], [NULL]);) 2025.11.13 09:24:54.867404 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:55.051701 [ 16233 ] {a72dcca0-27f1-475e-b1ea-c9bd2d9378ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1417, line 1420) (in query: SELECT toLowCardinality([NULL], [NULL], [NULL]);) 2025.11.13 09:24:55.078192 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:55.242938 [ 16233 ] {d7d8441f-476e-426f-a935-e81531bbdf72} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1418, line 1421) (in query: SELECT toMillisecond([NULL], [NULL], [NULL]);) 2025.11.13 09:24:55.333025 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:55.483236 [ 16233 ] {a8f091b7-c46e-4094-b208-0f41734cbbeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1419, line 1422) (in query: SELECT toMinute([NULL], [NULL], [NULL]);) 2025.11.13 09:24:55.502429 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:55.570864 [ 16233 ] {1388c68a-756a-4587-adc7-e2244988ea5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1420, line 1423) (in query: SELECT toModifiedJulianDay([NULL], [NULL], [NULL]);) 2025.11.13 09:24:55.625302 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:55.787678 [ 16233 ] {237e7295-13a3-4597-b22f-10dc58017321} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1421, line 1424) (in query: SELECT toModifiedJulianDayOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:24:55.809747 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:55.891475 [ 16233 ] {1349380c-090c-4a7d-b94a-011099e03fad} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonday([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1422, line 1425) (in query: SELECT toMonday([NULL], [NULL], [NULL]);) 2025.11.13 09:24:55.995363 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 566.49 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:55.999226 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 566.49 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:56.058041 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonday([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:56.086846 [ 10170 ] {c11e7bb5-4f04-49a0-87ae-98e2becb803f} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.29 MiB (attempt to allocate chunk of 1.60 MiB), maximum: 9.31 GiB: While executing JoiningTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38936) (comment: 03262_common_expression_optimization.sql) (query 60, line 110) (in query: -- JOIN expressions -- As the optimization code is shared between ON and WHERE, it is enough to test that the optimization is done also in ON SELECT * FROM x INNER JOIN y ON ((x.A = y.A ) AND x.B = 1) OR ((x.A = y.A) AND y.C = 1) ORDER BY ALL LIMIT 10 SETTINGS optimize_extract_common_expressions = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037ba70ae 10. ./src/Common/COW.h:293: DB::ColumnVector::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000037bbd3bf 11. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:191: DB::HashJoinMethods<(DB::JoinKind)0, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::joinBlockImpl(DB::HashJoin const&, DB::ScatteredBlock&, DB::Block const&, std::vector const*, std::allocator const*>> const&, bool) @ 0x0000000034b0d274 12. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:61: DB::HashJoinMethods<(DB::JoinKind)0, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::joinBlockImpl(DB::HashJoin const&, DB::Block&, DB::Block const&, std::vector const*, std::allocator const*>> const&, bool) @ 0x0000000034b0a431 13. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1073: _ZZN2DB8HashJoin9joinBlockERNS_5BlockERNSt3__110shared_ptrINS_10ExtraBlockEEEENK3$_0clINS3_17integral_constantINS_8JoinKindELSB_0EEENSA_INS_14JoinStrictnessELSD_3EEENS3_6vectorIPKNS0_12MapsTemplateINS_10RowRefListEEENS3_9allocatorISK_EEEEEEDaT_T0_RT1_ @ 0x0000000033c24a66 14. ./src/Interpreters/joinDispatch.h:158: bool func_wrapper, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0>(DB::JoinKind, DB::JoinStrictness, std::vector, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>> const*, std::allocator, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>> const*>>&, bool, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0&&)::'lambda'(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>)&, std::integral_constant>(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&&, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0&&) @ 0x0000000033c11af7 15. ./base/base/../base/constexpr_helpers.h:24: bool static_for_impl, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0>(DB::JoinKind, DB::JoinStrictness, std::vector>&, bool, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0&&)::'lambda'(int), 0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15, 16, 17, 18, 19, 20, 21, 22, 23>(bool DB::joinDispatch, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0>(DB::JoinKind, DB::JoinStrictness, std::vector>&, bool, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0&&)::'lambda'(int)&&, std::integer_sequence) @ 0x0000000033c009f0 16. ./base/base/../base/constexpr_helpers.h:31: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033bea182 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x000000003bb312b0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x000000003bb30551 19. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x000000003bb2ca24 20. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x000000003bb2b629 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:24:56.199749 [ 10170 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.29 MiB (attempt to allocate chunk of 1.60 MiB), maximum: 9.31 GiB: While executing JoiningTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037ba70ae 10. ./src/Common/COW.h:293: DB::ColumnVector::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x0000000037bbd3bf 11. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:191: DB::HashJoinMethods<(DB::JoinKind)0, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::joinBlockImpl(DB::HashJoin const&, DB::ScatteredBlock&, DB::Block const&, std::vector const*, std::allocator const*>> const&, bool) @ 0x0000000034b0d274 12. ./src/Interpreters/HashJoin/HashJoinMethodsImpl.h:61: DB::HashJoinMethods<(DB::JoinKind)0, (DB::JoinStrictness)3, DB::HashJoin::MapsTemplate>::joinBlockImpl(DB::HashJoin const&, DB::Block&, DB::Block const&, std::vector const*, std::allocator const*>> const&, bool) @ 0x0000000034b0a431 13. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:1073: _ZZN2DB8HashJoin9joinBlockERNS_5BlockERNSt3__110shared_ptrINS_10ExtraBlockEEEENK3$_0clINS3_17integral_constantINS_8JoinKindELSB_0EEENSA_INS_14JoinStrictnessELSD_3EEENS3_6vectorIPKNS0_12MapsTemplateINS_10RowRefListEEENS3_9allocatorISK_EEEEEEDaT_T0_RT1_ @ 0x0000000033c24a66 14. ./src/Interpreters/joinDispatch.h:158: bool func_wrapper, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0>(DB::JoinKind, DB::JoinStrictness, std::vector, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>> const*, std::allocator, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>> const*>>&, bool, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0&&)::'lambda'(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>)&, std::integral_constant>(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&&, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0&&) @ 0x0000000033c11af7 15. ./base/base/../base/constexpr_helpers.h:24: bool static_for_impl, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0>(DB::JoinKind, DB::JoinStrictness, std::vector>&, bool, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0&&)::'lambda'(int), 0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15, 16, 17, 18, 19, 20, 21, 22, 23>(bool DB::joinDispatch, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0>(DB::JoinKind, DB::JoinStrictness, std::vector>&, bool, DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&)::$_0&&)::'lambda'(int)&&, std::integer_sequence) @ 0x0000000033c009f0 16. ./base/base/../base/constexpr_helpers.h:31: DB::HashJoin::joinBlock(DB::Block&, std::shared_ptr&) @ 0x0000000033bea182 17. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:238: DB::JoiningTransform::readExecute(DB::Chunk&)::$_0::operator()() const @ 0x000000003bb312b0 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::JoiningTransform::readExecute(DB::Chunk&) @ 0x000000003bb30551 19. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:207: DB::JoiningTransform::transform(DB::Chunk&) @ 0x000000003bb2ca24 20. ./build_docker/./src/Processors/Transforms/JoiningTransform.cpp:137: DB::JoiningTransform::work() @ 0x000000003bb2b629 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 25. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:24:56.225636 [ 16233 ] {d128ee27-c2e6-4c76-9d9e-a9c4160a6c92} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1423, line 1426) (in query: SELECT toMonth([NULL], [NULL], [NULL]);) 2025.11.13 09:24:56.244476 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:56.315784 [ 16233 ] {8f17a9b1-3149-458e-8e4f-4a0b15ce73dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonthNumSinceEpoch doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonthNumSinceEpoch([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1424, line 1427) (in query: SELECT toMonthNumSinceEpoch([NULL], [NULL], [NULL]);) 2025.11.13 09:24:56.368801 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonthNumSinceEpoch doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonthNumSinceEpoch([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:56.482083 [ 16198 ] {41bfba71-93d8-4e23-a1fe-1fde871b68a2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34114) (comment: 03262_common_expression_optimization.sql) (in query: DROP DATABASE IF EXISTS test_8c5o5sa0 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:24:56.508131 [ 16233 ] {f3e8ecd9-59cb-4c6c-8cce-d840c61b6008} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1425, line 1428) (in query: SELECT toNullable([NULL], [NULL], [NULL]);) 2025.11.13 09:24:56.527239 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:56.579555 [ 16198 ] {41bfba71-93d8-4e23-a1fe-1fde871b68a2} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:56.582770 [ 16233 ] {6e28047d-9ce0-48cf-a197-fee5df1a022b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1426, line 1429) (in query: SELECT toQuarter([NULL], [NULL], [NULL]);) 2025.11.13 09:24:56.616892 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:56.679456 [ 16233 ] {a1c3464a-6e88-45e6-8c96-dc05651434ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeDayNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1427, line 1430) (in query: SELECT toRelativeDayNum([NULL], [NULL], [NULL]);) 2025.11.13 09:24:56.697611 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeDayNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:56.758359 [ 16233 ] {1d26d285-f5be-4f71-b968-efb8949e8e82} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeHourNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1428, line 1431) (in query: SELECT toRelativeHourNum([NULL], [NULL], [NULL]);) 2025.11.13 09:24:56.773968 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeHourNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:57.024452 [ 16233 ] {ea5f2fc0-9f92-4f99-a436-f2de070933a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMinuteNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1429, line 1432) (in query: SELECT toRelativeMinuteNum([NULL], [NULL], [NULL]);) 2025.11.13 09:24:57.048091 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMinuteNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:57.129647 [ 16233 ] {914b78a4-6bd6-4dfd-8fa8-b05bea4543f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMonthNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1430, line 1433) (in query: SELECT toRelativeMonthNum([NULL], [NULL], [NULL]);) 2025.11.13 09:24:57.145175 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMonthNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:57.224995 [ 16233 ] {ccb6f573-0e0f-410b-a35d-a95620456ed7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeQuarterNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1431, line 1434) (in query: SELECT toRelativeQuarterNum([NULL], [NULL], [NULL]);) 2025.11.13 09:24:57.261035 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeQuarterNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:57.433014 [ 16233 ] {030182d0-c8cf-469e-be8c-ff0e13591cc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeSecondNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1432, line 1435) (in query: SELECT toRelativeSecondNum([NULL], [NULL], [NULL]);) 2025.11.13 09:24:57.468343 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeSecondNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:57.532638 [ 16233 ] {4decdc30-f126-4ffb-8f3a-4bad5ba93424} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeWeekNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1433, line 1436) (in query: SELECT toRelativeWeekNum([NULL], [NULL], [NULL]);) 2025.11.13 09:24:57.551089 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeWeekNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:57.644746 [ 16233 ] {06f5280a-2ca1-485c-be64-5aaad9babd25} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeYearNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1434, line 1437) (in query: SELECT toRelativeYearNum([NULL], [NULL], [NULL]);) 2025.11.13 09:24:57.666597 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeYearNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:57.741777 [ 16233 ] {a6cb2835-0603-4885-bd7f-a42c9de4420a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1435, line 1438) (in query: SELECT toSecond([NULL], [NULL], [NULL]);) 2025.11.13 09:24:57.767147 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:57.907230 [ 16233 ] {82e21163-67ee-4103-857e-980faa73faec} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1436, line 1439) (in query: SELECT toStartOfDay([NULL], [NULL], [NULL]);) 2025.11.13 09:24:57.979192 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:58.054884 [ 16233 ] {5eaa5bdb-f2db-408e-80ec-f79596755ed2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1437, line 1440) (in query: SELECT toStartOfFifteenMinutes([NULL], [NULL], [NULL]);) 2025.11.13 09:24:58.075266 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:58.311261 [ 16233 ] {2d7daaa6-a7ef-4150-af63-faa314c0aa59} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1438, line 1441) (in query: SELECT toStartOfFiveMinute([NULL], [NULL], [NULL]);) 2025.11.13 09:24:58.408288 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:58.549993 [ 16233 ] {8c6b52d3-b120-4dfc-8e39-7ecaa71ad806} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1439, line 1442) (in query: SELECT toStartOfFiveMinutes([NULL], [NULL], [NULL]);) 2025.11.13 09:24:58.573629 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:58.681050 [ 16233 ] {e8231454-ab38-4de8-ab38-f4644651bbed} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1440, line 1443) (in query: SELECT toStartOfHour([NULL], [NULL], [NULL]);) 2025.11.13 09:24:58.700079 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:58.847642 [ 16233 ] {221615ae-0974-473d-8851-47ce2c76ce1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfISOYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1441, line 1444) (in query: SELECT toStartOfISOYear([NULL], [NULL], [NULL]);) 2025.11.13 09:24:58.873768 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfISOYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:58.965205 [ 16233 ] {5f2f2eb3-50c0-4869-b43d-36156c426ab2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfInterval([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1442, line 1445) (in query: SELECT toStartOfInterval([NULL], [NULL], [NULL]);) 2025.11.13 09:24:59.005629 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1st argument of function toStartOfInterval, expected a Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfInterval([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:24:59.181228 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 554.99 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:59.185444 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 554.99 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:24:59.315677 [ 16233 ] {98b9ea87-f117-447c-b26e-35b69cce3dca} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMicrosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1443, line 1446) (in query: SELECT toStartOfMicrosecond([NULL], [NULL], [NULL]);) 2025.11.13 09:24:59.414055 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMicrosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:59.489076 [ 16233 ] {ef1112a2-2272-49aa-b72b-3f8f650c68ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1444, line 1447) (in query: SELECT toStartOfMillisecond([NULL], [NULL], [NULL]);) 2025.11.13 09:24:59.506167 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:59.698115 [ 16233 ] {9f289ed7-bfff-4387-8065-eb405e0833dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1445, line 1448) (in query: SELECT toStartOfMinute([NULL], [NULL], [NULL]);) 2025.11.13 09:24:59.724149 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:24:59.893552 [ 16233 ] {e3fb3fa2-6d2b-4636-be43-ced89c7c58cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1446, line 1449) (in query: SELECT toStartOfMonth([NULL], [NULL], [NULL]);) 2025.11.13 09:24:59.924454 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:00.196283 [ 16233 ] {a54af426-aa65-45e5-a728-24db9f4eff87} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfNanosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1447, line 1450) (in query: SELECT toStartOfNanosecond([NULL], [NULL], [NULL]);) 2025.11.13 09:25:00.312312 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfNanosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:00.386626 [ 16233 ] {12bd5cb4-c4d6-49bd-8d01-8cf43bdd21ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1448, line 1451) (in query: SELECT toStartOfQuarter([NULL], [NULL], [NULL]);) 2025.11.13 09:25:00.405107 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:00.549138 [ 16233 ] {cd0efdab-ac3c-4b38-831f-4539219660d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1449, line 1452) (in query: SELECT toStartOfSecond([NULL], [NULL], [NULL]);) 2025.11.13 09:25:00.591334 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:00.698994 [ 16233 ] {439374d5-8cef-4358-bca7-7a0786f1ba0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfTenMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1450, line 1453) (in query: SELECT toStartOfTenMinutes([NULL], [NULL], [NULL]);) 2025.11.13 09:25:00.722581 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfTenMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:01.033476 [ 16233 ] {795de4b6-43db-473c-90fc-a1042108d267} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1451, line 1454) (in query: SELECT toStartOfWeek([NULL], [NULL], [NULL]);) 2025.11.13 09:25:01.054689 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:01.268066 [ 16233 ] {dfe930b8-d750-4fa5-80ac-ede3afda11db} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1452, line 1455) (in query: SELECT toStartOfYear([NULL], [NULL], [NULL]);) 2025.11.13 09:25:01.293923 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:01.382890 [ 16233 ] {d2fa2fb4-83f8-4149-b9cb-cff2b785560b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 3 arguments: In scope SELECT toString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1453, line 1456) (in query: SELECT toString([NULL], [NULL], [NULL]);) 2025.11.13 09:25:01.413440 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 3 arguments: In scope SELECT toString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:01.505899 [ 16233 ] {13b3a416-b01e-4b1e-87ad-a9a654740704} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1454, line 1457) (in query: SELECT toStringCutToZero([NULL], [NULL], [NULL]);) 2025.11.13 09:25:01.531144 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:01.664515 [ 16233 ] {60b58b46-00b0-40d3-9a0a-dc1a19eb74c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 3, should be 1 or 2: In scope SELECT toTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1455, line 1458) (in query: SELECT toTime([NULL], [NULL], [NULL]);) 2025.11.13 09:25:01.697931 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 3, should be 1 or 2: In scope SELECT toTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:01.815949 [ 16233 ] {a1917a13-23d8-4b74-a93a-c7da68ebe236} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1456, line 1459) (in query: SELECT toTimeZone([NULL], [NULL], [NULL]);) 2025.11.13 09:25:01.999563 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:02.074275 [ 16233 ] {82cb51e5-698d-4a74-938e-be8afccb7137} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1457, line 1460) (in query: SELECT toTimezone([NULL], [NULL], [NULL]);) 2025.11.13 09:25:02.098546 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 491.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:02.101484 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:02.101778 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 491.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:02.183330 [ 16233 ] {af159170-44ce-4165-8cad-ead0e1268f95} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1458, line 1461) (in query: SELECT toTypeName([NULL], [NULL], [NULL]);) 2025.11.13 09:25:02.210463 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:02.324550 [ 16233 ] {147a218d-e9c4-4fbe-bdca-1378146578e7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1459, line 1462) (in query: SELECT toUInt128([NULL], [NULL], [NULL]);) 2025.11.13 09:25:02.353210 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:02.481336 [ 16233 ] {85665278-95f0-4ca4-a7ab-3e7c02df2925} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1460, line 1463) (in query: SELECT toUInt128OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:25:02.512725 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:02.669999 [ 16233 ] {85df7ad9-df49-4b4d-aeca-43814626bbfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1461, line 1464) (in query: SELECT toUInt128OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:25:02.793293 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:02.984839 [ 16233 ] {83786dc8-52b4-45c1-a7d4-d079cf5ead5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1462, line 1465) (in query: SELECT toUInt128OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:25:03.010881 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:03.147510 [ 16233 ] {bb034c3a-4083-415e-a61d-88f4aadce839} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1463, line 1466) (in query: SELECT toUInt16([NULL], [NULL], [NULL]);) 2025.11.13 09:25:03.183111 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:03.344163 [ 16233 ] {3768d274-427d-4051-8b16-89a06e00ea98} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1464, line 1467) (in query: SELECT toUInt16OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:25:03.380969 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:03.482210 [ 16233 ] {db6ba531-eec2-438a-9670-3ffc31860b13} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1465, line 1468) (in query: SELECT toUInt16OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:25:03.507753 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:03.760202 [ 16233 ] {96245ac4-2a31-4ea5-8e6e-ae7fd944ebcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1466, line 1469) (in query: SELECT toUInt16OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:25:03.804903 [ 2997 ] {24cfa1ef-dc71-4cee-8c0e-febfa2746863} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_7.test_constraints (810853a3-cb80-4a86-bb8c-7cfc3db38ed7) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34028) (comment: 00953_constraints_operations.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:03.838710 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:03.854738 [ 2997 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_7.test_constraints (810853a3-cb80-4a86-bb8c-7cfc3db38ed7) is violated at row 1. Expression: (b > 0). Column values: b = 0. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:03.979931 [ 16233 ] {f0f5ecb6-f73a-4be6-a352-2678c044a1fa} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1467, line 1470) (in query: SELECT toUInt256([NULL], [NULL], [NULL]);) 2025.11.13 09:25:04.000652 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:04.108165 [ 16233 ] {26e1434a-51a4-4b14-aed1-7ccc0bc177b7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1468, line 1471) (in query: SELECT toUInt256OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:25:04.399347 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:04.499799 [ 16233 ] {7c2796bb-e064-4833-ad3a-b2f65a191443} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1469, line 1472) (in query: SELECT toUInt256OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:25:04.529128 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:04.714630 [ 16233 ] {4ef1150d-52e4-4d94-992e-be512f1123ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1470, line 1473) (in query: SELECT toUInt256OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:25:04.733824 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:04.909657 [ 16233 ] {fbfe7c2c-7514-4361-b373-8b6becbfe6c3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1471, line 1474) (in query: SELECT toUInt32([NULL], [NULL], [NULL]);) 2025.11.13 09:25:04.933627 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:05.017129 [ 16233 ] {dc6081ba-5d95-40a9-962f-4f6b9014ef08} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1472, line 1475) (in query: SELECT toUInt32OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:25:05.045375 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 524.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:05.048914 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_112_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 524.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:05.055302 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:05.289956 [ 16233 ] {97de5f92-5b37-4bdb-871d-8a17a7cfab01} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1473, line 1476) (in query: SELECT toUInt32OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:25:05.307925 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:05.446612 [ 16233 ] {4fd5f689-413d-4870-8416-84393348d8dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1474, line 1477) (in query: SELECT toUInt32OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:25:05.491631 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:05.497130 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:05.533010 [ 6078 ] {9d2d4573-81ae-4c6d-8f92-b2e34fed929f} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34016) (comment: 02378_part_log_profile_events.sh) (query 4, line 6) (in query: INSERT INTO test SELECT number AS key, sipHash64(number) AS val FROM numbers(512);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:25:05.535039 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:05.586887 [ 6078 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:25:05.612899 [ 16233 ] {47759545-9766-4d35-9b71-8cababfbee7b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1475, line 1478) (in query: SELECT toUInt64([NULL], [NULL], [NULL]);) 2025.11.13 09:25:05.634269 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:05.806515 [ 16233 ] {f97712fb-cd6c-47cb-bb57-b83cea652690} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1476, line 1479) (in query: SELECT toUInt64OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:25:05.827194 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:05.989428 [ 16233 ] {13f8897e-3b5c-4d61-abc8-4612830d62f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1477, line 1480) (in query: SELECT toUInt64OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:25:06.010893 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:06.200277 [ 16233 ] {b6de2746-6f7a-4f4e-afe9-d50be12c0040} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1478, line 1481) (in query: SELECT toUInt64OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:25:06.222919 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:06.312695 [ 16233 ] {e93efe2a-b27d-4b14-8477-896e084f45e6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1479, line 1482) (in query: SELECT toUInt8([NULL], [NULL], [NULL]);) 2025.11.13 09:25:06.331546 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:06.513433 [ 16233 ] {7ae27660-1681-4ce8-b2e3-e7e6d4b03afe} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1480, line 1483) (in query: SELECT toUInt8OrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:25:06.531846 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_222_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.80 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:06.533265 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:06.535139 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_222_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.80 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:06.611607 [ 16233 ] {4b9eee7d-5d48-4a22-b455-b6a70c7f9405} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1481, line 1484) (in query: SELECT toUInt8OrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:25:06.629751 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:06.702774 [ 16233 ] {00680c4c-897a-4745-bb5b-96f136968a27} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1482, line 1485) (in query: SELECT toUInt8OrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:25:06.722942 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:06.798353 [ 16233 ] {8f103305-4a21-4edc-a601-3c29eb7663a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1483, line 1486) (in query: SELECT toUTCTimestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:25:06.817653 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:06.894741 [ 16233 ] {3cbcb6f9-c1bf-4bfc-821a-0cf2a37dbfe6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 3 arguments: In scope SELECT toUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1484, line 1487) (in query: SELECT toUUID([NULL], [NULL], [NULL]);) 2025.11.13 09:25:06.914071 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 3 arguments: In scope SELECT toUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:07.163236 [ 16233 ] {770230d3-dd30-485c-8886-999dcd123ea5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1485, line 1488) (in query: SELECT toUUIDOrDefault([NULL], [NULL], [NULL]);) 2025.11.13 09:25:07.187965 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:07.323590 [ 16233 ] {db305f8d-0cad-4374-9873-98386f97ac72} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1486, line 1489) (in query: SELECT toUUIDOrNull([NULL], [NULL], [NULL]);) 2025.11.13 09:25:07.342303 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:07.443020 [ 16233 ] {aaa53c52-a53b-4f20-88c6-789e303ab182} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1487, line 1490) (in query: SELECT toUUIDOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:25:07.463304 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:07.636804 [ 16233 ] {b6538fb7-cb10-455e-8aab-dd644ddf9090} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUnixTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1488, line 1491) (in query: SELECT toUnixTimestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:25:07.653835 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUnixTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:07.754866 [ 16233 ] {45c265c8-ad57-4d46-8dcb-68a5df5dbac2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1489, line 1492) (in query: SELECT toUnixTimestamp64Micro([NULL], [NULL], [NULL]);) 2025.11.13 09:25:07.777120 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:07.879021 [ 2997 ] {23406e91-9941-4189-9999-83df24971510} executeQuery: Code: 497. DB::Exception: user03247_test_11_17690: Not enough privileges. To execute this query, it's necessary to have the grant SHOW TABLES ON test_03247.`table`. (ACCESS_DENIED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34074) (comment: 03247_show_grants_with_implicit.sh) (query 1, line 1) (in query: EXISTS test_03247.table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e3a78db 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e3a3d96 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e3a2306 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e31aa78 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003186786f 8. ./build_docker/./src/Interpreters/Context.cpp:1751: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000317cbe0f 9. ./build_docker/./src/Interpreters/InterpreterExistsQuery.cpp:54: DB::InterpreterExistsQuery::executeImpl() @ 0x000000003395dcc7 10. ./build_docker/./src/Interpreters/InterpreterExistsQuery.cpp:25: DB::InterpreterExistsQuery::execute() @ 0x000000003395c944 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:07.925881 [ 2997 ] {} TCPHandler: Code: 497. DB::Exception: user03247_test_11_17690: Not enough privileges. To execute this query, it's necessary to have the grant SHOW TABLES ON test_03247.`table`. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x000000002e3a78db 4. ./build_docker/./src/Access/ContextAccess.cpp:673: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x000000002e3a3d96 5. ./build_docker/./src/Access/ContextAccess.cpp:711: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000002e3a2306 6. ./build_docker/./src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002e31aa78 7. ./src/Access/ContextAccess.h:256: void DB::Context::checkAccessImpl>, std::basic_string_view>>(DB::AccessFlags const&, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x000000003186786f 8. ./build_docker/./src/Interpreters/Context.cpp:1751: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000317cbe0f 9. ./build_docker/./src/Interpreters/InterpreterExistsQuery.cpp:54: DB::InterpreterExistsQuery::executeImpl() @ 0x000000003395dcc7 10. ./build_docker/./src/Interpreters/InterpreterExistsQuery.cpp:25: DB::InterpreterExistsQuery::execute() @ 0x000000003395c944 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:07.959228 [ 16233 ] {471d5bdc-4ab9-49ea-8528-4c9944b189a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1490, line 1493) (in query: SELECT toUnixTimestamp64Milli([NULL], [NULL], [NULL]);) 2025.11.13 09:25:07.998575 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:08.038550 [ 16889 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:08.128534 [ 16233 ] {a009ab90-c549-4b4e-8412-510a9eb8fb21} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1491, line 1494) (in query: SELECT toUnixTimestamp64Nano([NULL], [NULL], [NULL]);) 2025.11.13 09:25:08.148498 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:08.348510 [ 16233 ] {d6ae1438-8886-45c8-b9b7-45e7a6d071bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1492, line 1495) (in query: SELECT toUnixTimestamp64Second([NULL], [NULL], [NULL]);) 2025.11.13 09:25:08.478537 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Second doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Second([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:08.574016 [ 16233 ] {ac8894ff-5f10-4cb4-9b7a-57169da17871} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1493, line 1496) (in query: SELECT toValidUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:25:08.688879 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:08.767220 [ 16233 ] {560866c3-0c44-458b-946d-604f13b4d55c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1494, line 1497) (in query: SELECT toWeek([NULL], [NULL], [NULL]);) 2025.11.13 09:25:08.785489 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:08.894469 [ 16233 ] {ee554ae8-6071-4293-ad9e-57b828831339} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1495, line 1498) (in query: SELECT toYYYYMM([NULL], [NULL], [NULL]);) 2025.11.13 09:25:08.913372 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:09.049482 [ 16233 ] {4434716f-c80f-45df-8772-7bbe389a4b00} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1496, line 1499) (in query: SELECT toYYYYMMDD([NULL], [NULL], [NULL]);) 2025.11.13 09:25:09.068880 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:09.149443 [ 16233 ] {74b24547-d714-4e41-8e1d-b6b2a782e562} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1497, line 1500) (in query: SELECT toYYYYMMDDhhmmss([NULL], [NULL], [NULL]);) 2025.11.13 09:25:09.170412 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:09.384467 [ 16233 ] {6a2db9ca-de2a-403a-9a6d-5548a56ddeec} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1498, line 1501) (in query: SELECT toYear([NULL], [NULL], [NULL]);) 2025.11.13 09:25:09.400300 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 601.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:09.403389 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 601.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:09.417465 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:09.492116 [ 16233 ] {84b83029-c48c-4740-80b2-344091ce62de} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYearNumSinceEpoch doesn't match: passed 3, should be 1 or 2: In scope SELECT toYearNumSinceEpoch([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1499, line 1502) (in query: SELECT toYearNumSinceEpoch([NULL], [NULL], [NULL]);) 2025.11.13 09:25:09.514402 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYearNumSinceEpoch doesn't match: passed 3, should be 1 or 2: In scope SELECT toYearNumSinceEpoch([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:09.679025 [ 16233 ] {fcfad798-c9b2-4528-8a45-8a9a7496d60d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toYearWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1500, line 1503) (in query: SELECT toYearWeek([NULL], [NULL], [NULL]);) 2025.11.13 09:25:09.702595 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toYearWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:09.882756 [ 16233 ] {024bfe03-7c1e-4041-bc28-864051dd012c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1501, line 1504) (in query: SELECT to_utc_timestamp([NULL], [NULL], [NULL]);) 2025.11.13 09:25:09.950331 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:10.052011 [ 16233 ] {b584c5ba-326f-480c-a30f-a0add5a117d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1502, line 1505) (in query: SELECT today([NULL], [NULL], [NULL]);) 2025.11.13 09:25:10.077882 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:10.114569 [ 19621 ] {fd6ad3af-b97d-4e03-ae6b-278f6a7685d9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55358) (comment: 00094_union_race_conditions_5.sh) (query 46, line 46) (in query: SELECT * FROM system.numbers_mt LIMIT 111;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:25:10.306425 [ 19621 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:25:10.344475 [ 16233 ] {c6000394-78bc-497a-844f-690fa0623205} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1503, line 1506) (in query: SELECT tokens([NULL], [NULL], [NULL]);) 2025.11.13 09:25:10.375737 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:10.671602 [ 16233 ] {e8ce2a05-4f20-4eb5-98d2-6c3ae207a1ec} executeQuery: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1504, line 1507) (in query: SELECT topK([NULL], [NULL], [NULL]);) 2025.11.13 09:25:10.689768 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:10.871439 [ 16233 ] {a82c7706-afce-487a-90f4-1075325c6136} executeQuery: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1505, line 1508) (in query: SELECT topKWeighted([NULL], [NULL], [NULL]);) 2025.11.13 09:25:10.888673 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:11.002825 [ 16233 ] {ea7cfc8c-5f2b-42f7-b890-5e469101ebb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1506, line 1509) (in query: SELECT topLevelDomain([NULL], [NULL], [NULL]);) 2025.11.13 09:25:11.024305 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:11.168418 [ 16233 ] {e8e72019-4f08-42a2-b6ed-728c2030cbc1} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1507, line 1510) (in query: SELECT topLevelDomainRFC([NULL], [NULL], [NULL]);) 2025.11.13 09:25:11.202585 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:11.301687 [ 16233 ] {237b1117-bcae-40f3-b7da-fac81fe89e54} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1508, line 1511) (in query: SELECT transactionID([NULL], [NULL], [NULL]);) 2025.11.13 09:25:11.331097 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:11.495833 [ 16233 ] {abf4b77d-910d-45ed-a423-6d3a06f29a59} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1509, line 1512) (in query: SELECT transactionLatestSnapshot([NULL], [NULL], [NULL]);) 2025.11.13 09:25:11.589514 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:11.710426 [ 16233 ] {c5e0de20-a53b-47f3-b77a-096dfad6abf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1510, line 1513) (in query: SELECT transactionOldestSnapshot([NULL], [NULL], [NULL]);) 2025.11.13 09:25:11.732511 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:11.855426 [ 16233 ] {8cf03b7d-adc6-42c4-85b3-1b5ab7a91daf} executeQuery: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types: In scope SELECT transform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1511, line 1514) (in query: SELECT transform([NULL], [NULL], [NULL]);) 2025.11.13 09:25:11.875332 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types: In scope SELECT transform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:11.988738 [ 16233 ] {e51eee71-eac1-4e28-b56a-a8998a2a1366} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function translate: In scope SELECT translate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1512, line 1515) (in query: SELECT translate([NULL], [NULL], [NULL]);) 2025.11.13 09:25:12.013095 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function translate: In scope SELECT translate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:12.165937 [ 16233 ] {06d6c3c1-9f46-4bae-b408-0a34083c5029} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function translateUTF8: In scope SELECT translateUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1513, line 1516) (in query: SELECT translateUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:25:12.182691 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function translateUTF8: In scope SELECT translateUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:12.343395 [ 16233 ] {dda820d9-8c15-4674-a06a-7f7b695b332d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimBoth'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimBoth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1514, line 1518) (in query: SELECT trimBoth([NULL], [NULL], [NULL]);) 2025.11.13 09:25:12.357416 [ 16344 ] {b3699031-5386-43c6-9118-88057c37ab01} executeQuery: Code: 469. DB::Exception: Constraint `b_constraint` for table test_7.test_constraints (810853a3-cb80-4a86-bb8c-7cfc3db38ed7) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60878) (comment: 00953_constraints_operations.sh) (query 1, line 1) (in query: INSERT INTO test_constraints VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:12.362767 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimBoth'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimBoth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:12.383131 [ 16344 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `b_constraint` for table test_7.test_constraints (810853a3-cb80-4a86-bb8c-7cfc3db38ed7) is violated at row 1. Expression: (b > 10). Column values: b = 10. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:12.571275 [ 16233 ] {6479e035-e721-4a08-8ab6-e889334bf8f2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimLeft'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1515, line 1519) (in query: SELECT trimLeft([NULL], [NULL], [NULL]);) 2025.11.13 09:25:12.616824 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.85 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:12.619536 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.85 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:12.679393 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimLeft'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:12.701670 [ 16887 ] {b210dfc2-315b-480e-88bf-25a86b9160a2} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.78 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45150) (comment: 03326_parallel_replicas_out_of_range.sql) (query 3, line 8) (in query: SELECT count(materialize(toLowCardinality(1))) IGNORE NULLS AS num, hostName() AS hostName FROM system.query_log AS a INNER JOIN system.processes AS b ON (type = toFixedString(toNullable('QueryStart'), 10)) AND (dateDiff('second', event_time, now()) > 5) AND (current_database = currentDatabase()) FORMAT `Null`;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:25:12.746740 [ 16233 ] {7ab887cc-e9c9-4737-a743-143f0ba74a3f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimRight'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1516, line 1520) (in query: SELECT trimRight([NULL], [NULL], [NULL]);) 2025.11.13 09:25:12.772446 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trimRight'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trimRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:12.790255 [ 16887 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.78 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:25:12.854690 [ 16233 ] {87c1915a-c0a5-4a09-b4ba-5a2ea38d15cb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trunc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1517, line 1521) (in query: SELECT trunc([NULL], [NULL], [NULL]);) 2025.11.13 09:25:12.872732 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trunc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:13.150988 [ 16233 ] {5ad674f6-fa6d-40ff-914a-331d7d9ad1b1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT truncate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1518, line 1522) (in query: SELECT truncate([NULL], [NULL], [NULL]);) 2025.11.13 09:25:13.177030 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT truncate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:13.407427 [ 16233 ] {a30fabe5-a4af-4e4f-aac6-290d20670a60} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1519, line 1523) (in query: SELECT tryBase58Decode([NULL], [NULL], [NULL]);) 2025.11.13 09:25:13.426294 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:13.493515 [ 16233 ] {7dc6c563-5d56-431e-b44e-a2090a04a41b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1520, line 1524) (in query: SELECT tryBase64Decode([NULL], [NULL], [NULL]);) 2025.11.13 09:25:13.509992 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:13.581407 [ 16233 ] {0d627a32-eb7c-411e-b4b5-d3d3e89a76ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1521, line 1525) (in query: SELECT tryBase64URLDecode([NULL], [NULL], [NULL]);) 2025.11.13 09:25:13.603070 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:13.853980 [ 16233 ] {3bf1e57a-f045-469b-a734-e9f4314b0e4c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'tryDecrypt'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT tryDecrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1522, line 1526) (in query: SELECT tryDecrypt([NULL], '[HIDDEN]')) 2025.11.13 09:25:13.874771 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'tryDecrypt'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT tryDecrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:14.152805 [ 16233 ] {a71ebc92-0a33-45e5-9263-7d9e9e285333} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1523, line 1527) (in query: SELECT tryIdnaEncode([NULL], [NULL], [NULL]);) 2025.11.13 09:25:14.175231 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:14.269975 [ 16233 ] {06f4296f-30ff-4cd8-9436-91e66da9530f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1524, line 1528) (in query: SELECT tryPunycodeDecode([NULL], [NULL], [NULL]);) 2025.11.13 09:25:14.287809 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:14.456042 [ 16233 ] {3ab09e43-f46c-4cdd-9420-0a5f7d4683f5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumble. Should be a date with time: In scope SELECT tumble([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1525, line 1529) (in query: SELECT tumble([NULL], [NULL], [NULL]);) 2025.11.13 09:25:14.478476 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumble. Should be a date with time: In scope SELECT tumble([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:14.533095 [ 16141 ] {62528802-cf4b-4d97-89d5-4a64b68f6ed2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47750) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_01516_test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:25:14.552467 [ 16233 ] {34e11a73-e0c9-4179-b431-6a323802338b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumbleEnd. Should be a date with time: In scope SELECT tumbleEnd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1526, line 1530) (in query: SELECT tumbleEnd([NULL], [NULL], [NULL]);) 2025.11.13 09:25:14.574537 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumbleEnd. Should be a date with time: In scope SELECT tumbleEnd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:14.626237 [ 16141 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:25:14.714740 [ 16233 ] {56ae30c2-e777-4181-8688-7a3aa38d13af} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumbleStart. Should be a date with time: In scope SELECT tumbleStart([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1527, line 1531) (in query: SELECT tumbleStart([NULL], [NULL], [NULL]);) 2025.11.13 09:25:14.742939 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumbleStart. Should be a date with time: In scope SELECT tumbleStart([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:15.008987 [ 16233 ] {895b0bd8-b26d-4825-a1e2-97efa5a1c077} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function tupleConcat: In scope SELECT tupleConcat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1529, line 1533) (in query: SELECT tupleConcat([NULL], [NULL], [NULL]);) 2025.11.13 09:25:15.031257 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function tupleConcat: In scope SELECT tupleConcat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:15.064149 [ 18392 ] {ef6194bd-0761-4141-91a6-91945c43570f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46926) (comment: 03208_multiple_joins_with_storage_join.sql) (in query: DROP DATABASE IF EXISTS test_jg056y6j SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:25:15.075915 [ 18392 ] {ef6194bd-0761-4141-91a6-91945c43570f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:15.112667 [ 16233 ] {5b1c38b4-a184-48c5-98bc-e896c2cec602} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1530, line 1534) (in query: SELECT tupleDivide([NULL], [NULL], [NULL]);) 2025.11.13 09:25:15.141341 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:15.329604 [ 16233 ] {b5ac974a-24cd-4b6c-859e-515de9541846} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1531, line 1535) (in query: SELECT tupleDivideByNumber([NULL], [NULL], [NULL]);) 2025.11.13 09:25:15.354120 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:15.527319 [ 16233 ] {ae23980a-9869-4754-8149-e490d8b38cbc} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Array(Nullable(Nothing)): In scope SELECT tupleElement([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1532, line 1536) (in query: SELECT tupleElement([NULL], [NULL], [NULL]);) 2025.11.13 09:25:15.587921 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Array(Nullable(Nothing)): In scope SELECT tupleElement([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:15.613681 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 532.25 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:15.616341 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 532.25 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:15.680282 [ 16233 ] {35eb16df-2d19-4051-9edb-3617b1fd9075} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1533, line 1537) (in query: SELECT tupleHammingDistance([NULL], [NULL], [NULL]);) 2025.11.13 09:25:15.723468 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:15.871809 [ 16233 ] {fd4f9b95-f1c9-4c9d-a5f4-829501c0e25f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1534, line 1538) (in query: SELECT tupleIntDiv([NULL], [NULL], [NULL]);) 2025.11.13 09:25:15.890083 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:16.152796 [ 16233 ] {b4eed95a-1aad-4194-8153-995777e7aad2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1535, line 1539) (in query: SELECT tupleIntDivByNumber([NULL], [NULL], [NULL]);) 2025.11.13 09:25:16.171092 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:16.316792 [ 16233 ] {cc919df1-024a-4c69-bab0-352acda8a795} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1536, line 1540) (in query: SELECT tupleIntDivOrZero([NULL], [NULL], [NULL]);) 2025.11.13 09:25:16.339864 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:16.460025 [ 16233 ] {428994f7-8b64-4521-9fef-f2ac3befef29} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1537, line 1541) (in query: SELECT tupleIntDivOrZeroByNumber([NULL], [NULL], [NULL]);) 2025.11.13 09:25:16.478364 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:16.557685 [ 16233 ] {a05b2b60-80ab-4117-83e5-841f77ae91f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1538, line 1542) (in query: SELECT tupleMinus([NULL], [NULL], [NULL]);) 2025.11.13 09:25:16.574892 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:16.664475 [ 16233 ] {d40b1236-8489-4902-a8fa-981ae32c64f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1539, line 1543) (in query: SELECT tupleModulo([NULL], [NULL], [NULL]);) 2025.11.13 09:25:16.691980 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:16.807927 [ 16233 ] {e98ddc10-edc0-4de2-b833-b8d39c24ace9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1540, line 1544) (in query: SELECT tupleModuloByNumber([NULL], [NULL], [NULL]);) 2025.11.13 09:25:16.839172 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:16.975826 [ 16233 ] {35688f18-3da7-4d13-a030-93c820835943} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1541, line 1545) (in query: SELECT tupleMultiply([NULL], [NULL], [NULL]);) 2025.11.13 09:25:17.038650 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:17.194673 [ 16233 ] {0b8528d5-7488-4720-9665-c537552e6620} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1542, line 1546) (in query: SELECT tupleMultiplyByNumber([NULL], [NULL], [NULL]);) 2025.11.13 09:25:17.218696 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:17.426781 [ 16233 ] {e4a9b569-98e9-4517-9560-de8c2ccf02a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1543, line 1547) (in query: SELECT tupleNames([NULL], [NULL], [NULL]);) 2025.11.13 09:25:17.444913 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:17.502772 [ 16233 ] {648addef-4eef-46d1-9aad-85974664a3aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1544, line 1548) (in query: SELECT tupleNegate([NULL], [NULL], [NULL]);) 2025.11.13 09:25:17.522730 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:17.589041 [ 16233 ] {3592fcf1-87f3-4060-b7c2-3c67da5c8413} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1545, line 1549) (in query: SELECT tuplePlus([NULL], [NULL], [NULL]);) 2025.11.13 09:25:17.609274 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:17.738636 [ 16233 ] {6e6d5b23-f6e4-4fa0-9462-26fbb21d0417} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1546, line 1550) (in query: SELECT tupleToNameValuePairs([NULL], [NULL], [NULL]);) 2025.11.13 09:25:17.761026 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:17.847240 [ 16233 ] {8fd3f7fe-2bd1-45ca-b497-ab3078d7c47e} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1547, line 1551) (in query: SELECT ucase([NULL], [NULL], [NULL]);) 2025.11.13 09:25:17.884330 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:17.946255 [ 16233 ] {6c9f4de5-ab93-4e52-88a5-c0bd791f9e86} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1548, line 1552) (in query: SELECT unbin([NULL], [NULL], [NULL]);) 2025.11.13 09:25:17.963787 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:18.087749 [ 16233 ] {119c58cd-0508-40a4-9b08-2f9004cc6855} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1549, line 1553) (in query: SELECT unhex([NULL], [NULL], [NULL]);) 2025.11.13 09:25:18.143466 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 495.82 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:18.145654 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 495.82 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:18.174118 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:19.596119 [ 18700 ] {9ddddc40-1b67-4d63-bf48-c032bac0e609} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '202001-06' to Date. (CANNOT_PARSE_DATE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60942) (comment: 01073_bad_alter_partition.sql) (query 11, line 19) (in query: ALTER TABLE merge_tree DROP PARTITION '202001-06';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000001f9b238c 5. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000001f9b1dec 6. ./src/IO/ReadHelpers.h:829: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000027090bb3 7. ./src/IO/ReadHelpers.h:850: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cbb2a 8. ./build_docker/./src/DataTypes/Serializations/SerializationDate.cpp:20: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cb96b 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003377fa14 10. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 11. ./build_docker/./src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000033782bed 12. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6408: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000039937638 13. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5460: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000039990c59 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032992043 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:25:19.603330 [ 18700 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: while converting '202001-06' to Date. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x000000001f9b238c 5. ./build_docker/./src/IO/ReadHelpers.cpp:0: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000001f9b1dec 6. ./src/IO/ReadHelpers.h:829: void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000027090bb3 7. ./src/IO/ReadHelpers.h:850: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cbb2a 8. ./build_docker/./src/DataTypes/Serializations/SerializationDate.cpp:20: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f5cb96b 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x000000003377fa14 10. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x00000000337798fe 11. ./build_docker/./src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000033782bed 12. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:6408: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000039937638 13. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5460: DB::MergeTreeData::checkAlterPartitionIsPossible(std::vector> const&, std::shared_ptr const&, DB::Settings const&, std::shared_ptr) const @ 0x0000000039990c59 14. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:241: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032992043 15. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:25:19.712423 [ 16233 ] {d7ab375f-b40a-434b-ad50-d7366791d21e} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1556, line 1560) (in query: SELECT uniqThetaIntersect([NULL], [NULL], [NULL]);) 2025.11.13 09:25:19.749189 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:19.812595 [ 16233 ] {b6d36580-8978-4f02-ba61-ce522a978112} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1557, line 1561) (in query: SELECT uniqThetaNot([NULL], [NULL], [NULL]);) 2025.11.13 09:25:19.825389 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:19.885485 [ 16233 ] {418c44f3-08a1-412b-ab43-0e9d1121bb17} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1558, line 1562) (in query: SELECT uniqThetaUnion([NULL], [NULL], [NULL]);) 2025.11.13 09:25:19.898767 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:19.982747 [ 16186 ] {79d32034-4222-4609-8aae-0c2d000e43fc} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:32862) (comment: 02000_join_on_const.sql) (query 7, line 10) (in query: SELECT 70 = 10 * sum(t1.id) + sum(t2.id) AND count() == 4 FROM t1 JOIN t2 ON 1 = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:529: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000032d07b72 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2042: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c76c5d 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:25:19.993283 [ 16186 ] {} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:529: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000032d07b72 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2042: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c76c5d 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:25:20.148801 [ 16233 ] {4f5a2433-bb8b-4cdb-8d7b-ed3f67e507b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1560, line 1564) (in query: SELECT upper([NULL], [NULL], [NULL]);) 2025.11.13 09:25:20.160311 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:20.338546 [ 16233 ] {4ff8c148-467f-43e3-b9f9-b8f7fc57ecca} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1561, line 1565) (in query: SELECT upperUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:25:20.352271 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:20.362290 [ 19606 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:20.363280 [ 19606 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:20.403906 [ 16233 ] {64d35f78-0c19-45cd-9fab-421974679785} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1562, line 1566) (in query: SELECT uptime([NULL], [NULL], [NULL]);) 2025.11.13 09:25:20.417175 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:20.462915 [ 16233 ] {7c2ffaa0-d732-46dc-9d7a-c28f1e1b18cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1563, line 1567) (in query: SELECT user([NULL], [NULL], [NULL]);) 2025.11.13 09:25:20.473704 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:20.479093 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 504.98 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:20.481059 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 504.98 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:20.519919 [ 16233 ] {8dbd2b18-c07e-45a8-9654-d97cfdea6b8a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function validateNestedArraySizes Must be UInt.: In scope SELECT validateNestedArraySizes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1564, line 1568) (in query: SELECT validateNestedArraySizes([NULL], [NULL], [NULL]);) 2025.11.13 09:25:20.532688 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function validateNestedArraySizes Must be UInt.: In scope SELECT validateNestedArraySizes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:20.632519 [ 16233 ] {32abc7a2-aab3-4ff2-be11-ef1dcb48ac18} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1565, line 1569) (in query: SELECT varPop([NULL], [NULL], [NULL]);) 2025.11.13 09:25:20.645475 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:20.719304 [ 16233 ] {7c3aca24-d26e-425d-9cc1-4c5ba0f9389a} executeQuery: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1566, line 1570) (in query: SELECT varPopStable([NULL], [NULL], [NULL]);) 2025.11.13 09:25:20.732323 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:20.816944 [ 16233 ] {33ca215c-53d4-4883-9b67-4ec21426f2b9} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1567, line 1571) (in query: SELECT varSamp([NULL], [NULL], [NULL]);) 2025.11.13 09:25:20.832994 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:20.893660 [ 16233 ] {27b7c97b-2e09-42a6-b4c8-08e0c3653901} executeQuery: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1568, line 1572) (in query: SELECT varSampStable([NULL], [NULL], [NULL]);) 2025.11.13 09:25:20.904594 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:21.101698 [ 16233 ] {151c7c14-8ff0-4a1f-abe9-9dea78513d03} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Array(Nullable(Nothing)): In scope SELECT variantElement([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1569, line 1573) (in query: SELECT variantElement([NULL], [NULL], [NULL]);) 2025.11.13 09:25:21.118693 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Array(Nullable(Nothing)): In scope SELECT variantElement([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:21.221892 [ 16233 ] {ee47bfaa-7e41-4177-a0ad-4607a60aa591} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1570, line 1574) (in query: SELECT variantType([NULL], [NULL], [NULL]);) 2025.11.13 09:25:21.234434 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:21.283542 [ 16233 ] {3c7dc854-8103-4b5e-b23f-284a1f0cc685} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1571, line 1575) (in query: SELECT vectorDifference([NULL], [NULL], [NULL]);) 2025.11.13 09:25:21.295955 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:21.342598 [ 16233 ] {0f7b2942-60c6-4778-a26d-3701b7851c2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1572, line 1576) (in query: SELECT vectorSum([NULL], [NULL], [NULL]);) 2025.11.13 09:25:21.385434 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:21.626764 [ 16233 ] {55e8ec9f-ed0c-4573-8b1a-f3c2f9aec104} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1573, line 1577) (in query: SELECT version([NULL], [NULL], [NULL]);) 2025.11.13 09:25:21.637958 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:21.779278 [ 16233 ] {0a6a9896-a9e7-421a-9141-7b2a6b988a22} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1574, line 1578) (in query: SELECT visibleWidth([NULL], [NULL], [NULL]);) 2025.11.13 09:25:21.790787 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:21.834926 [ 16233 ] {78768ce3-572f-46c9-bbde-878c3aea3b7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1575, line 1579) (in query: SELECT visitParamExtractBool([NULL], [NULL], [NULL]);) 2025.11.13 09:25:21.846707 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:21.894074 [ 16233 ] {5c3f73a2-034b-41c5-9142-a976c46a88f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1576, line 1580) (in query: SELECT visitParamExtractFloat([NULL], [NULL], [NULL]);) 2025.11.13 09:25:21.967840 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:22.131120 [ 16233 ] {d8db3bcc-1291-4466-aef0-7dd06b2dca1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1577, line 1581) (in query: SELECT visitParamExtractInt([NULL], [NULL], [NULL]);) 2025.11.13 09:25:22.145261 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:22.235159 [ 16233 ] {a4c83126-ad42-4b6b-a8bf-8b47bdee1bba} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1578, line 1582) (in query: SELECT visitParamExtractRaw([NULL], [NULL], [NULL]);) 2025.11.13 09:25:22.247649 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:22.298847 [ 16233 ] {96934ca7-9446-4818-9081-05c1d286361f} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1579, line 1583) (in query: SELECT visitParamExtractString([NULL], [NULL], [NULL]);) 2025.11.13 09:25:22.314363 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:22.373431 [ 16233 ] {5bade63f-23ed-4333-ab48-a73142580e77} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1580, line 1584) (in query: SELECT visitParamExtractUInt([NULL], [NULL], [NULL]);) 2025.11.13 09:25:22.386242 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:22.434635 [ 16233 ] {ec5940ef-1be1-4288-a95b-639bf25bea91} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1581, line 1585) (in query: SELECT visitParamHas([NULL], [NULL], [NULL]);) 2025.11.13 09:25:22.446883 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:22.447301 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 476.73 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:22.449449 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 476.73 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:22.582096 [ 16233 ] {aa46528d-58b4-4e9c-899a-528e435eaa38} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT week([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1582, line 1586) (in query: SELECT week([NULL], [NULL], [NULL]);) 2025.11.13 09:25:22.595240 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT week([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:22.721638 [ 16233 ] {e830fb19-eb83-4ccd-a995-98b9b1590453} executeQuery: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1583, line 1587) (in query: SELECT welchTTest([NULL], [NULL], [NULL]);) 2025.11.13 09:25:22.741236 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:22.792753 [ 16233 ] {ef5b6277-eec9-435d-a7f4-7f31f9bc060e} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1584, line 1588) (in query: SELECT widthBucket([NULL], [NULL], [NULL]);) 2025.11.13 09:25:22.805829 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:22.951500 [ 16233 ] {962bd2a2-bb4c-4576-a8bf-12e80335a007} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1585, line 1589) (in query: SELECT width_bucket([NULL], [NULL], [NULL]);) 2025.11.13 09:25:22.970395 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:23.032536 [ 16233 ] {ab587a22-ca1b-4093-9337-e8bb08deeda3} executeQuery: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1586, line 1590) (in query: SELECT windowFunnel([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.048881 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:23.096900 [ 16233 ] {07e8c38f-afaf-449a-aa72-68f6233bc4e9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function windowID. Should be a date with time: In scope SELECT windowID([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1587, line 1591) (in query: SELECT windowID([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.109024 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function windowID. Should be a date with time: In scope SELECT windowID([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:23.162971 [ 16233 ] {1415dda1-3bb6-47ae-80e8-e24b048313e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1588, line 1592) (in query: SELECT wkt([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.231385 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:23.283753 [ 16233 ] {73db9d81-6954-4c6d-baf0-49841f71245d} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1589, line 1593) (in query: SELECT wordShingleMinHash([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.297488 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:23.412111 [ 16233 ] {264de5cb-5f13-434a-8df8-01c9252691c9} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1590, line 1594) (in query: SELECT wordShingleMinHashArg([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.426288 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:23.483452 [ 16233 ] {a4a8b94f-9480-4323-a568-d280e38ff212} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1591, line 1595) (in query: SELECT wordShingleMinHashArgCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.498869 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:23.562497 [ 16233 ] {fb547c9a-266a-4e11-9097-219f2df7812a} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1592, line 1596) (in query: SELECT wordShingleMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.577294 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:23.631030 [ 16233 ] {bc417a60-3535-49bd-b448-97a022aa18e9} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1593, line 1597) (in query: SELECT wordShingleMinHashArgUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.645539 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:23.695286 [ 16233 ] {682cde38-aafb-4244-8c78-741666ce63a8} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1594, line 1598) (in query: SELECT wordShingleMinHashCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.767182 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:23.878951 [ 16233 ] {aa90633e-0304-48d0-9efa-8b1e45e25404} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1595, line 1599) (in query: SELECT wordShingleMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.896591 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:23.950262 [ 16233 ] {9b9cee99-5f4d-474a-bc3e-42436883aaa8} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1596, line 1600) (in query: SELECT wordShingleMinHashUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:25:23.963124 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:24.020712 [ 16233 ] {2de9a00c-1197-4876-a546-ec230f9cb531} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1597, line 1601) (in query: SELECT wordShingleSimHash([NULL], [NULL], [NULL]);) 2025.11.13 09:25:24.046620 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:24.102842 [ 16233 ] {e0e379cb-6c71-48cd-bb65-e462f3bb19c2} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1598, line 1602) (in query: SELECT wordShingleSimHashCaseInsensitive([NULL], [NULL], [NULL]);) 2025.11.13 09:25:24.118018 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:24.169621 [ 16233 ] {00005a1b-de3a-4013-82b4-fd59b9dc9c50} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1599, line 1603) (in query: SELECT wordShingleSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:25:24.183508 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:24.233923 [ 16233 ] {cccf922f-14a2-4c2e-aaeb-0b721cf26396} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1600, line 1604) (in query: SELECT wordShingleSimHashUTF8([NULL], [NULL], [NULL]);) 2025.11.13 09:25:24.248144 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:24.341139 [ 16186 ] {9e5d845b-922d-43a4-81a0-0ff3a3be0aef} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 539.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60000) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: CREATE TABLE IF NOT EXISTS test_01516_test_1.data1 ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 13313, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 112, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 169350409, compact_parts_max_granules_to_buffer = 188, compact_parts_merge_max_bytes_to_prefetch_part = 66909, merge_max_block_size = 8184, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26983051, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 17, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 35540, primary_key_compress_block_size = 61589, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true AS SELECT * FROM numbers(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:25:24.366536 [ 16186 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 539.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:25:24.389130 [ 19619 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 532.03 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:24.390232 [ 19619 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 532.03 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:24.400724 [ 19619 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 529.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:24.401882 [ 19619 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 529.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:24.604866 [ 16233 ] {966d624a-8e13-4712-aab6-6eb24df424ae} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function xor: In scope SELECT xor([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1602, line 1606) (in query: SELECT xor([NULL], [NULL], [NULL]);) 2025.11.13 09:25:24.617090 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function xor: In scope SELECT xor([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:24.986126 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 539.25 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:24.988060 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 539.25 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:25.155646 [ 16186 ] {e154a8cc-293c-41c5-bf3d-ec09c69e6fb1} executeQuery: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60044) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 DELETE WHERE ignore(rand())), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:25.169321 [ 16186 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:25.340677 [ 3737 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_93_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 468.64 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:25.341611 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:25.342565 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.52 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:25.344656 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_93_15}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 468.64 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:25.624858 [ 16233 ] {e5a5a499-9109-46cc-a887-b434fbfe004c} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1606, line 1610) (in query: SELECT yandexConsistentHash([NULL], [NULL], [NULL]);) 2025.11.13 09:25:25.645011 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:25.880960 [ 3727 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_157_35} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 495.69 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:25.882884 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_157_35}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 495.69 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:25.891419 [ 16233 ] {ccfc7f76-2d4e-4d43-91ad-fcda65379a37} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT yearweek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1607, line 1611) (in query: SELECT yearweek([NULL], [NULL], [NULL]);) 2025.11.13 09:25:25.904068 [ 16233 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT yearweek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.11.13 09:25:25.916580 [ 16186 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 495.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:25.917540 [ 16186 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 495.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:25.950374 [ 16233 ] {af02f886-fde7-423a-978b-021b5bc8a5c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1608, line 1612) (in query: SELECT yesterday([NULL], [NULL], [NULL]);) 2025.11.13 09:25:25.972598 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:26.025368 [ 16233 ] {99ea1a71-931a-4d1a-bffa-55defe32de29} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56600) (comment: 00534_functions_bad_arguments13.sh) (query 1609, line 1613) (in query: SELECT zookeeperSessionUptime([NULL], [NULL], [NULL]);) 2025.11.13 09:25:26.038570 [ 16233 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.11.13 09:25:26.049169 [ 16186 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 496.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:26.050333 [ 16186 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 496.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:26.346276 [ 16872 ] {abb8b99c-785d-47c5-b6b2-1146a80344ed} StorageBuffer (test_11.mt_buffer_00158): Caught exception while adding data to buffer, rolling back...: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.38 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 6. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 7. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b29a0d 13. ./src/Columns/IColumn.h:210: DB::BufferSink::insertIntoBuffer(DB::Block const&, DB::StorageBuffer::Buffer&, int) @ 0x0000000038fc664b 14. ./build_docker/./src/Storages/StorageBuffer.cpp:738: DB::BufferSink::consume(DB::Chunk&) @ 0x0000000038fc42e4 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:26.354073 [ 19499 ] {abb8b99c-785d-47c5-b6b2-1146a80344ed} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.38 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59994) (comment: 00158_buffer_and_nonexistent_table.sql) (query 6, line 7) (in query: INSERT INTO test_11.mt_buffer_00158 (x) SELECT number AS x FROM system.numbers LIMIT 100000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 6. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 7. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b29a0d 13. ./src/Columns/IColumn.h:210: DB::BufferSink::insertIntoBuffer(DB::Block const&, DB::StorageBuffer::Buffer&, int) @ 0x0000000038fc664b 14. ./build_docker/./src/Storages/StorageBuffer.cpp:738: DB::BufferSink::consume(DB::Chunk&) @ 0x0000000038fc42e4 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:25:26.392310 [ 19499 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.38 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 6. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 7. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b29a0d 13. ./src/Columns/IColumn.h:210: DB::BufferSink::insertIntoBuffer(DB::Block const&, DB::StorageBuffer::Buffer&, int) @ 0x0000000038fc664b 14. ./build_docker/./src/Storages/StorageBuffer.cpp:738: DB::BufferSink::consume(DB::Chunk&) @ 0x0000000038fc42e4 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 23. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:25:26.396698 [ 17385 ] {8eda183f-51ae-43b9-bd2f-1d4c456239a2} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 493.01 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59978) (comment: 01073_blockSerializedSize.sql) (query 14, line 18) (in query: select 'uniqCombinedState(100)', blockSerializedSize(uniqCombinedState(number)) from (select number from system.numbers limit 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:26.396797 [ 19619 ] {bffb1c8a-7bb7-4212-b408-79b4eaadba73} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.23 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60056) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: CREATE TABLE IF NOT EXISTS test_01516_test_1.data2 ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 13313, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 112, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 169350409, compact_parts_max_granules_to_buffer = 188, compact_parts_merge_max_bytes_to_prefetch_part = 66909, merge_max_block_size = 8184, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 26983051, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 17, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 35540, primary_key_compress_block_size = 61589, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true AS SELECT * FROM numbers(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:25:26.470792 [ 19619 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.23 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:25:26.484997 [ 17385 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 493.01 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:25:26.819569 [ 16186 ] {cc424a6d-eef1-4fc6-a0f5-3d52593be9d6} executeQuery: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60116) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 UPDATE y = x + arrayCount(x -> (x + y) % 2, range(y)) WHERE not ignore()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:26.832589 [ 16186 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:27.096967 [ 3903 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryLogElement]: Failed to flush system log system.query_log with 875 entries up to offset 61292: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.66 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037acb88e 10. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037c88a80 11. ./src/Columns/ColumnsCommon.h:125: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037adf589 12. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037adf30e 13. ./src/Columns/ColumnLowCardinality.h:140: DB::ColumnLowCardinality::index(DB::IColumn const&, unsigned long) const @ 0x00000000375d86c4 14. ./build_docker/./src/Columns/ColumnArray.cpp:959: COW::immutable_ptr DB::ColumnArray::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000370bbadb 15. ./src/Columns/ColumnsCommon.h:136: DB::ColumnArray::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000370ab628 16. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:47: DB::permuteBlockIfNeeded(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039829bfb 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:189: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba572d 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 22. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 30. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332cf2e1 31. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x00000000332cc91e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:27.274500 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 560.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:27.276872 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 560.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:27.489497 [ 17255 ] {385a2521-1cb0-4bd4-9619-414288cf445a} HashedDictionary: Exception had been thrown during parallel load of the dictionary: Code: 241. DB::Exception: (total) memory limit exceeded: would use 488.12 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 6. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 7. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f627ee4 11. HashTable, HashTableNoState, PairNoInit>, DefaultHash, DB::HashedDictionaryImpl::HashTableGrowerWithPrecalculationAndMaxLoadFactor<8ul>, Allocator>::resize(unsigned long, unsigned long) @ 0x00000000286e10a1 12. auto DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::blockToAttributes(DB::Block const&, DB::DictionaryKeysArenaHolder<(DB::DictionaryKeyType)0>&, unsigned long)::'lambda'(auto&)::operator(), HashTableNoState, PairNoInit>, DefaultHash, DB::HashedDictionaryImpl::HashTableGrowerWithPrecalculationAndMaxLoadFactor<8ul>, Allocator>, std::allocator, HashTableNoState, PairNoInit>, DefaultHash, DB::HashedDictionaryImpl::HashTableGrowerWithPrecalculationAndMaxLoadFactor<8ul>, Allocator>>>>(auto&) const @ 0x00000000287624e2 13. void detail::static_for::getAttributeContainers::blockToAttributes(DB::Block const&, DB::DictionaryKeysArenaHolder<(DB::DictionaryKeyType)0>&, unsigned long)::'lambda'(auto&)>(unsigned long, auto&&)::'lambda'(auto const&)&>(DB::AttributeUnderlyingType, auto&&)::'lambda'(auto), 0ul, 1ul, 2ul, 3ul, 4ul, 5ul, 6ul, 7ul, 8ul, 9ul, 10ul, 11ul, 12ul, 13ul, 14ul, 15ul, 16ul, 17ul, 18ul, 19ul, 20ul, 21ul, 22ul, 23ul>(void DB::callOnDictionaryAttributeType::getAttributeContainers::blockToAttributes(DB::Block const&, DB::DictionaryKeysArenaHolder<(DB::DictionaryKeyType)0>&, unsigned long)::'lambda'(auto&)>(unsigned long, auto&&)::'lambda'(auto const&)&>(DB::AttributeUnderlyingType, auto&&)::'lambda'(auto)&&, std::integer_sequence) @ 0x000000002875f033 14. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::blockToAttributes(DB::Block const&, DB::DictionaryKeysArenaHolder<(DB::DictionaryKeyType)0>&, unsigned long) @ 0x00000000282ff0ec 15. DB::HashedDictionaryImpl::HashedDictionaryParallelLoader<(DB::DictionaryKeyType)0, DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>>::threadWorker(unsigned long, DB::HashedDictionaryImpl::HashedDictionaryParallelLoader<(DB::DictionaryKeyType)0, DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>>::WorkerStatistic&) @ 0x0000000028464791 16. DB::HashedDictionaryImpl::HashedDictionaryParallelLoader<(DB::DictionaryKeyType)0, DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>>::HashedDictionaryParallelLoader(DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>&)::'lambda'()::operator()() const @ 0x0000000028463cd9 17. void std::__function::__policy_invoker::__call_impl[abi:ne190107]>::HashedDictionaryParallelLoader(DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000028462e7f 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. DB::HashedDictionaryImpl::HashedDictionaryParallelLoader<(DB::DictionaryKeyType)0, DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>>::HashedDictionaryParallelLoader(DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>&) @ 0x0000000028460e59 5. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f09b5 6. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 8. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 10. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 11. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 12. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 13. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:27.900714 [ 19499 ] {38c0a960-2c1e-497d-b4e5-936987f2d69a} executeQuery: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60172) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 UPDATE y = x + arrayCount(x -> (rand() + x) % 2, range(y)) WHERE not ignore()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:27.926934 [ 19499 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:28.312752 [ 17227 ] {bb9438c9-90f0-4f4d-8936-547c3e17e669} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 460.13 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: while converting source column number to destination column a: while executing 'FUNCTION _CAST(number :: 0, Int32 :: 3) -> _CAST(number, Int32) Int32 : 6'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59880) (comment: 01606_merge_from_wide_to_compact.sql) (query 14, line 27) (in query: INSERT INTO wide_to_comp SELECT number, number, number FROM numbers(100000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c115fc 12. ./src/Functions/FunctionsConversion.h:1674: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002caf892c 13. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caf0259 14. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c942fe3 15. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96febd 16. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96ee02 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 21. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 22. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 23. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 27. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 28. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 29. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 30. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 2025.11.13 09:25:28.358284 [ 17227 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 460.13 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: while converting source column number to destination column a: while executing 'FUNCTION _CAST(number :: 0, Int32 :: 3) -> _CAST(number, Int32) Int32 : 6'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c115fc 12. ./src/Functions/FunctionsConversion.h:1674: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002caf892c 13. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002caf0259 14. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c942fe3 15. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96febd 16. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c96ee02 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 21. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 22. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 23. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 27. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 28. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 29. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 30. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:25:28.646089 [ 19499 ] {ace7ee82-3f0f-445e-83bc-7de3298c898a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60216) (comment: 01516_drop_table_stress_long.sh) (query 1, line 1) (in query: DROP DATABASE IF EXISTS test_01516_test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:25:28.661322 [ 19499 ] {} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:25:28.896879 [ 19619 ] {1ebfa32b-a64f-4110-bbd4-1ee7d6474a59} executeQuery: Code: 60. DB::Exception: Could not find table: table_1017_merge. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60232) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_merge DELETE WHERE rand() = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:28.911550 [ 19619 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: table_1017_merge. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:29.272907 [ 17255 ] {385a2521-1cb0-4bd4-9619-414288cf445a} ExternalDictionariesLoader: Could not load external dictionary '1119b8f4-92d2-4582-bb09-e8200cde5e0e', next update is scheduled at 2025-11-13 09:25:32: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.23 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 6. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 7. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037af5fce 12. ./build_docker/./src/Columns/IColumn.cpp:254: DB::IColumnHelper, DB::ColumnFixedSizeHelper>::scatter(unsigned long, DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000381886b8 13. DB::HashedDictionaryImpl::HashedDictionaryParallelLoader<(DB::DictionaryKeyType)0, DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>>::splitBlock(DB::PODArray, 63ul, 64ul> const&, DB::Block const&) @ 0x0000000028784b75 14. DB::HashedDictionaryImpl::HashedDictionaryParallelLoader<(DB::DictionaryKeyType)0, DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>>::addBlock(DB::Block) @ 0x000000002830202b 15. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0d13 16. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 18. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 20. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 21. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 22. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 23. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:29.278326 [ 16203 ] {385a2521-1cb0-4bd4-9619-414288cf445a} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.23 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:59914) (comment: 02730_dictionary_hashed_load_factor_element_count.sql) (query 10, line 13) (in query: SYSTEM RELOAD DICTIONARY dict_sharded_multi;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 6. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 7. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037af5fce 12. ./build_docker/./src/Columns/IColumn.cpp:254: DB::IColumnHelper, DB::ColumnFixedSizeHelper>::scatter(unsigned long, DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000381886b8 13. DB::HashedDictionaryImpl::HashedDictionaryParallelLoader<(DB::DictionaryKeyType)0, DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>>::splitBlock(DB::PODArray, 63ul, 64ul> const&, DB::Block const&) @ 0x0000000028784b75 14. DB::HashedDictionaryImpl::HashedDictionaryParallelLoader<(DB::DictionaryKeyType)0, DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>>::addBlock(DB::Block) @ 0x000000002830202b 15. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0d13 16. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 18. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 20. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 21. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 22. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 23. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:25:29.303663 [ 19499 ] {1a2167b3-022e-40ff-a311-bffa237640bd} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a ORC format file. Error: std::exception. Code: 1001, type: orc::ParseError, e.what() = Footer is corrupt: STRUCT type 0 has 3 subTypes, but has 2 fieldNames (version 25.3.8.10072.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/corrupted.orc). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60262) (comment: 02185_orc_corrupted_file.sh) (query 1, line 1) (in query: select * from file('corrupted.orc')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a3f964d 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ee8e9 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:25:29.312316 [ 16203 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.23 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 6. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 7. ./build_docker/./src/Common/MemoryTracker.cpp:255: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84eee3 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037af5fce 12. ./build_docker/./src/Columns/IColumn.cpp:254: DB::IColumnHelper, DB::ColumnFixedSizeHelper>::scatter(unsigned long, DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000381886b8 13. DB::HashedDictionaryImpl::HashedDictionaryParallelLoader<(DB::DictionaryKeyType)0, DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>>::splitBlock(DB::PODArray, 63ul, 64ul> const&, DB::Block const&) @ 0x0000000028784b75 14. DB::HashedDictionaryImpl::HashedDictionaryParallelLoader<(DB::DictionaryKeyType)0, DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>>::addBlock(DB::Block) @ 0x000000002830202b 15. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0d13 16. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 18. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 20. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 21. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 22. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 23. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&) @ 0x00000000328ccfb9 5. ./build_docker/./src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000328c5b1e 6. ./build_docker/./src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x000000003290ef74 7. ./contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoadOrReload(String const&, std::chrono::duration>) @ 0x00000000328bee7d 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1407: std::shared_ptr DB::ExternalLoader::loadOrReload, void>(String const&) const @ 0x00000000328b8522 9. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:108: DB::ExternalDictionariesLoader::reloadDictionary(String const&, std::shared_ptr) const @ 0x00000000328a4fe5 10. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:584: DB::InterpreterSystemQuery::execute() @ 0x00000000338e1aad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:29.316854 [ 19499 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a ORC format file. Error: std::exception. Code: 1001, type: orc::ParseError, e.what() = Footer is corrupt: STRUCT type 0 has 3 subTypes, but has 2 fieldNames (version 25.3.8.10072.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/corrupted.orc). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000001a3f964d 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0ee8e9 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003b0f096e 6. ./build_docker/./src/Storages/StorageFile.cpp:985: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385000fb 7. ./build_docker/./src/Storages/StorageFile.cpp:998: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000385015fe 8. ./build_docker/./src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000038504671 9. ./build_docker/./src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000038509de7 10. ./build_docker/./src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x000000003850bb80 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000026761155 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x000000002675b181 13. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000026764f8b 14. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x000000002d18c5ed 15. ./build_docker/./src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000317e585f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4995: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000030425508 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:25:29.554015 [ 18149 ] {9ab84e2e-d130-461d-9a3a-a64de375bd80} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36118) (comment: 02730_dictionary_hashed_load_factor_element_count.sql) (in query: DROP DATABASE IF EXISTS test_9hufdy9z SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:25:29.587619 [ 18149 ] {9ab84e2e-d130-461d-9a3a-a64de375bd80} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6cf51 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a73e2a 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:29.707722 [ 16186 ] {2ec7623d-97ac-4438-b893-c77b6720a6e5} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60176) (comment: 02915_sleep_large_uint.sql) (query 1, line 1) (in query: SELECT sleep(3.40282e+44);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001a603b71 5. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a602a3d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:25:29.717984 [ 16186 ] {} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001a603b71 5. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a602a3d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:25:29.961622 [ 18149 ] {b0ef2fa2-b838-4196-9d26-24c5860daea6} executeQuery: Code: 60. DB::Exception: Could not find table: table_1017_merge. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60288) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_merge UPDATE y = y + rand() % 1 WHERE not ignore()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:30.030926 [ 18149 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: table_1017_merge. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:30.182072 [ 16186 ] {60e4a60b-1add-4893-91da-af56710240dc} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60176) (comment: 02915_sleep_large_uint.sql) (query 2, line 2) (in query: SELECT sleep((pow(2, 64) / 1000000) - 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001a603b71 5. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a602a3d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:25:30.193582 [ 16186 ] {} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001a603b71 5. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a602a3d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:25:30.929572 [ 19619 ] {bd7522df-8b95-4f5f-be1b-8dfafadac7d7} executeQuery: Code: 62. DB::Exception: Unrecognized token: Syntax error: failed at position 11 (#): #. . (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44764) (comment: 02192_comment_error.sh) (in query: select 42 #), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5c6a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:30.935550 [ 19619 ] {bd7522df-8b95-4f5f-be1b-8dfafadac7d7} DynamicQueryHandler: Code: 62. DB::Exception: Unrecognized token: Syntax error: failed at position 11 (#): #. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5c6a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:30.997897 [ 16355 ] {90b01894-b0a9-4a44-a32f-bc1a386c2ece} executeQuery: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35828) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 UPDATE y = joinGet('test_13.lookup_table', 'y_new', y) WHERE x=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:31.020564 [ 16355 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:31.119609 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 653.25 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:429: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6b672a 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:31.122611 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 653.25 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:429: DB::SerializationMap::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6b672a 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:31.794057 [ 16186 ] {78bac925-9a05-4b16-bd66-dbb2019b3a34} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60176) (comment: 02915_sleep_large_uint.sql) (query 3, line 3) (in query: SELECT sleepEachRow(184467440737095516) from numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001a605e5c 5. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a604bbd 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:25:31.803548 [ 16186 ] {} TCPHandler: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001a605e5c 5. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a604bbd 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000301fd196 11. ./build_docker/./src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000301f982e 12. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003bb0ef37 13. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x000000003c1005d2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000032c1077f 15. ./build_docker/./src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bfa640 16. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 20. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 21. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 23. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 26. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:25:32.002337 [ 19619 ] {8ee5d3c9-76bd-480d-8892-3da54016099f} executeQuery: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35870) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 DELETE WHERE dictHas('test_13.dict1', toUInt64(x))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:32.014087 [ 19619 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:32.965154 [ 19499 ] {1616666f-3ecf-4d7d-8841-1fb7f8f4509c} executeQuery: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35888) (comment: 01017_mutations_with_nondeterministic_functions_zookeeper.sh) (query 1, line 1) (in query: ALTER TABLE table_1017_1 DELETE WHERE dictHas('test_13.dict1', toUInt64(x))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:32.978255 [ 19499 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: table_1017_1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:33.104088 [ 16186 ] {64020e41-94e9-4a2b-9016-3afe98408fb2} executeQuery: Code: 160. DB::Exception: The maximum sleep time is 4294967295 microseconds. Requested: 2147483648000000 microseconds: while executing 'FUNCTION sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String) :: 1) -> sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String)) UInt8 : 2'. (TOO_SLOW) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60176) (comment: 02915_sleep_large_uint.sql) (query 5, line 5) (in query: SELECT sleepEachRow(pow(2, 31)) from numbers(9007199254740992) settings function_sleep_max_microseconds_per_block = 8589934592000000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000008c4592d 4. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001a605fd3 5. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a604b3a 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:25:33.118710 [ 16186 ] {} TCPHandler: Code: 160. DB::Exception: The maximum sleep time is 4294967295 microseconds. Requested: 2147483648000000 microseconds: while executing 'FUNCTION sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String) :: 1) -> sleepEachRow(_CAST(2147483648._Float64, 'Float64'_String)) UInt8 : 2'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x0000000008c4592d 4. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001a605fd3 5. DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a604b3a 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:25:33.611516 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 547.12 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:33.613476 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 547.12 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:34.240345 [ 16354 ] {d86fcf70-0a8a-4bd6-8d76-5d93a0070908} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 537.31 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_1_112_12/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 3951): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44780) (comment: 00974_text_log_table_not_empty.sh) (in query: SELECT count() > 0 FROM system.text_log WHERE position(system.text_log.message, 'SELECT 6103') > 0 AND event_date >= yesterday() SETTINGS max_rows_to_read = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 2025.11.13 09:25:34.260151 [ 16354 ] {d86fcf70-0a8a-4bd6-8d76-5d93a0070908} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 537.31 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_1_112_12/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 3951): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c2eb431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 9. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:35.214093 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 491.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:35.214938 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 514.27 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:35.215253 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 491.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:35.216970 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 514.27 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:35.228619 [ 3726 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_89_94_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 491.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_92_92_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:35.230399 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_89_94_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 491.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_92_92_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:35.711859 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:35.713044 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:36.042551 [ 16355 ] {0b7d21cd-a0f8-41a0-85d0-ada9d42757bb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35960) (comment: 01030_final_mark_empty_primary_key.sql) (query 4, line 6) (in query: SELECT sum(x) from empty_pk;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:25:36.091357 [ 16355 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:25:36.181743 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_233_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 509.65 MiB (attempt to allocate chunk of 1.53 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:36.183957 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_233_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 509.65 MiB (attempt to allocate chunk of 1.53 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:36.273868 [ 3738 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_140_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 491.57 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column plan_step_name): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_134_11/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:36.276240 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_140_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 491.57 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column plan_step_name): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_134_11/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:36.456710 [ 15982 ] {fae9eba9-8af7-46d1-9c6f-45a8bea8b43e} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35950) (comment: 00804_test_delta_codec_no_type_alter.sql) (query 8, line 9) (in query: ALTER TABLE delta_codec_for_alter MODIFY COLUMN x UInt64 Codec(Delta, LZ4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationEntry.cpp:62: DB::MergeTreeMutationEntry::MergeTreeMutationEntry(DB::MutationCommands, std::shared_ptr, String const&, unsigned long, DB::TransactionID const&, DB::WriteSettings const&) @ 0x000000003a556e18 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:572: DB::StorageMergeTree::startMutation(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4a938d 19. ./build_docker/./src/Storages/StorageMergeTree.cpp:460: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a4a63cc 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991221 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:25:36.466300 [ 15982 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationEntry.cpp:62: DB::MergeTreeMutationEntry::MergeTreeMutationEntry(DB::MutationCommands, std::shared_ptr, String const&, unsigned long, DB::TransactionID const&, DB::WriteSettings const&) @ 0x000000003a556e18 18. ./build_docker/./src/Storages/StorageMergeTree.cpp:572: DB::StorageMergeTree::startMutation(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4a938d 19. ./build_docker/./src/Storages/StorageMergeTree.cpp:460: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000003a4a63cc 20. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991221 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:25:36.827009 [ 17710 ] {} ExternalDictionariesLoader: Could not load external dictionary '1119b8f4-92d2-4582-bb09-e8200cde5e0e', next update is scheduled at 2025-11-13 09:25:41: Code: 60. DB::Exception: Unknown table expression identifier 'test_9hufdy9z.dict_data' in scope SELECT key, v0, v1, v2, v3, v4 FROM test_9hufdy9z.dict_data. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000002702efa8 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x000000002702e915 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0a87 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:37.237151 [ 17226 ] {9bb6c9c2-4b74-4177-83b9-c79594e855e4} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `b` in scope SELECT a + 1 AS b, b + 1 AS a FROM (SELECT 10 AS a). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35910) (comment: 00818_alias_bug_4110.sql) (query 13, line 15) (in query: select a + 1 as b, b + 1 as a from (select 10 as a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1243: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030447274 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1494: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449c4e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:25:37.309964 [ 17226 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `b` in scope SELECT a + 1 AS b, b + 1 AS a FROM (SELECT 10 AS a). Maybe you meant: ['b']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1243: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030447274 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1494: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000030449c4e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3693: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414c9a 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:25:37.341560 [ 3739 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 569.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:37.344055 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 569.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:37.458453 [ 3731 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_140_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 569.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:37.460614 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_140_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 569.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:38.576205 [ 17226 ] {c8da48ce-9194-404f-984c-903e82217fea} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT 10 AS a, a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35910) (comment: 00818_alias_bug_4110.sql) (query 14, line 16) (in query: select 10 as a, a + 1 as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:25:38.584777 [ 17226 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT 10 AS a, a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:25:38.623592 [ 17226 ] {8a594f49-d8bc-4f21-b43b-0ba6fc45a0a5} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope WITH 10 AS a SELECT a AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35910) (comment: 00818_alias_bug_4110.sql) (query 15, line 17) (in query: with 10 as a select a as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:25:38.632084 [ 17226 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope WITH 10 AS a SELECT a AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:25:38.677888 [ 18391 ] {17b3b544-7b6b-4623-9049-892c3241839b} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statements with nondeterministic deterministic functions cannot be applied on fly. Function 'rand' is non-deterministic. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36038) (comment: 03047_on_fly_mutations_non_deterministic.sql) (query 7, line 12) (in query: SELECT * FROM t_lightweight_mut_2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/AlterConversions.cpp:99: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x0000000039afa409 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8688: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039a3e103 6. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:158: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x000000003c340b24 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:53: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c33f0fd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:118: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c3d30b6 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:ne190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x000000003c2fe580 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003c26b684 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:757: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003c277a9e 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:965: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003c27aace 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2128: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003c2c322f 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2226: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c9ebb 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:25:38.684397 [ 17226 ] {2e9e13a5-32c7-4f53-a490-7fd37c669388} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope WITH 10 AS a SELECT a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35910) (comment: 00818_alias_bug_4110.sql) (query 16, line 18) (in query: with 10 as a select a + 1 as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:25:38.686269 [ 18391 ] {} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statements with nondeterministic deterministic functions cannot be applied on fly. Function 'rand' is non-deterministic. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/MergeTree/AlterConversions.cpp:99: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x0000000039afa409 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8688: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039a3e103 6. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:158: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x000000003c340b24 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:53: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c33f0fd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:118: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c3d30b6 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:ne190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x000000003c2fe580 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003c26b684 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:757: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003c277a9e 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:965: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003c27aace 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2128: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003c2c322f 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2226: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c9ebb 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:25:38.692248 [ 17226 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope WITH 10 AS a SELECT a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:25:38.911352 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.38 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:38.913951 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.38 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:39.045414 [ 3735 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_140_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 480.69 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column plan_step_name): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_134_11/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:39.047499 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_140_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 480.69 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column plan_step_name): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_134_11/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:40.244103 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_233_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.73 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_228_1/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 6170): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1191: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForOneColumn() const @ 0x00000000397ce3a3 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1463: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77f6 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:40.247038 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_233_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.73 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_228_1/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 6170): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1191: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForOneColumn() const @ 0x00000000397ce3a3 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1463: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77f6 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:40.437374 [ 19620 ] {32a78c20-bf5f-410f-80a3-9c7a60ff169d} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 2 (error): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE, EXECUTE AS query, EXECUTE AS. (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45424) (in query: error here ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5c6a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:40.443198 [ 19620 ] {32a78c20-bf5f-410f-80a3-9c7a60ff169d} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 2 (error): error here . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE WORKLOAD query, DROP WORKLOAD query, CREATE RESOURCE query, DROP RESOURCE query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, CHECK GRANT, CHECK GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE, EXECUTE AS query, EXECUTE AS. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5c6a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 5. ./build_docker/./src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x00000000338252b8 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 7. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 8. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:40.465662 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 530.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:40.500610 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 553.14 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:40.502910 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 553.14 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:41.108290 [ 18403 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:41.109588 [ 18403 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:41.308148 [ 3730 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_140_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 553.08 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column plan_step): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_134_11/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:41.310066 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_140_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 553.08 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column plan_step): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_134_11/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:41.793229 [ 5803 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.66 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:41.794428 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.66 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:41.939899 [ 3724 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.01 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:41.942237 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.01 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:41.977101 [ 5803 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:41.978276 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.005096 [ 18391 ] {6ac09613-709f-4120-a74c-a90a605edd40} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic and cannot be applied on fly. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36038) (comment: 03047_on_fly_mutations_non_deterministic.sql) (query 13, line 21) (in query: SELECT * FROM t_lightweight_mut_2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/AlterConversions.cpp:95: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x0000000039afa2de 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8688: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039a3e103 6. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:158: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x000000003c340b24 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:53: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c33f0fd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:118: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c3d30b6 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:ne190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x000000003c2fe580 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003c26b684 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:757: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003c277a9e 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:965: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003c27aace 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2128: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003c2c322f 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2226: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c9ebb 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:25:42.015886 [ 18391 ] {} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic and cannot be applied on fly. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Storages/MergeTree/AlterConversions.cpp:95: DB::AlterConversions::addMutationCommand(DB::MutationCommand const&) @ 0x0000000039afa2de 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:8688: DB::MergeTreeData::getAlterConversionsForPart(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000039a3e103 6. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:158: DB::MergeTreeReadPoolBase::fillPerPartInfos(DB::Settings const&) @ 0x000000003c340b24 7. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:53: DB::MergeTreeReadPoolBase::MergeTreeReadPoolBase(DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c33f0fd 8. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:118: DB::MergeTreeReadPoolParallelReplicas::MergeTreeReadPoolParallelReplicas(DB::ParallelReadingExtension, DB::RangesInDataParts&&, std::shared_ptr, std::unordered_map, std::equal_to, std::allocator>>, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ExpressionActionsSettings const&, DB::MergeTreeReaderSettings const&, std::vector> const&, DB::MergeTreeReadPoolBase::PoolSettings const&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr const&) @ 0x000000003c3d30b6 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeReadPoolParallelReplicas* std::construct_at[abi:ne190107]&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&, DB::MergeTreeReadPoolParallelReplicas*>(DB::MergeTreeReadPoolParallelReplicas*, DB::ParallelReadingExtension&&, DB::RangesInDataParts&&, std::shared_ptr&, std::unordered_map, std::equal_to, std::allocator>>&, std::shared_ptr&, std::shared_ptr&, std::shared_ptr&, DB::ExpressionActionsSettings&, DB::MergeTreeReaderSettings&, std::vector>&, DB::MergeTreeReadPoolBase::PoolSettings&, DB::MergeTreeReadTask::BlockSizeParams const&, std::shared_ptr&) @ 0x000000003c2fe580 10. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReadFromMergeTree::readFromPoolParallelReplicas(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadPoolBase::PoolSettings) @ 0x000000003c26b684 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:757: DB::ReadFromMergeTree::read(DB::RangesInDataParts, std::vector>, DB::MergeTreeReadType, unsigned long, unsigned long, bool) @ 0x000000003c277a9e 12. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:965: DB::ReadFromMergeTree::spreadMarkRangesAmongStreams(DB::RangesInDataParts&&, unsigned long, std::vector> const&) @ 0x000000003c27aace 13. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2128: DB::ReadFromMergeTree::spreadMarkRanges(DB::RangesInDataParts&&, unsigned long, DB::ReadFromMergeTree::AnalysisResult&, std::optional&) @ 0x000000003c2c322f 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2226: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c2c9ebb 15. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 16. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:25:42.546532 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.60 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.549275 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.60 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.638272 [ 5803 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.639408 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.665602 [ 3728 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.71 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_133_27/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 1 with max_rows_to_read = 8235): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.668229 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.71 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_133_27/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 1 with max_rows_to_read = 8235): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.668810 [ 17376 ] {04d4a138-871f-4314-8952-725e40dd16b4} executeQuery: Code: 36. DB::Exception: Default codec cannot have any arguments, it's just an alias for codec specified in config.xml. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36172) (comment: 01455_default_compression.sql) (query 10, line 27) (in query: ALTER TABLE compress_table MODIFY COLUMN value2 CODEC(Default(5));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:118: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003de780da 5. ./build_docker/./src/Storages/AlterCommands.cpp:1502: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003829c7e0 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:25:42.679565 [ 17376 ] {} TCPHandler: Code: 36. DB::Exception: Default codec cannot have any arguments, it's just an alias for codec specified in config.xml. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:118: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003de780da 5. ./build_docker/./src/Storages/AlterCommands.cpp:1502: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003829c7e0 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:25:42.703141 [ 5803 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.704520 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.871931 [ 3732 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_135_141_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.03 MiB (attempt to allocate chunk of 1.19 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.873341 [ 5803 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.874461 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_135_141_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.03 MiB (attempt to allocate chunk of 1.19 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:42.874848 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.028584 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_233_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.03 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnDecimal::shrinkToFit() @ 0x0000000037211f44 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1191: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForOneColumn() const @ 0x00000000397ce3a3 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1463: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77f6 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 24. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.031032 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_233_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.03 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnDecimal::shrinkToFit() @ 0x0000000037211f44 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1191: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForOneColumn() const @ 0x00000000397ce3a3 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1463: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77f6 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 24. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.272896 [ 3733 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.62 MiB (attempt to allocate chunk of 1.27 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_133_27/data.bin (position: 404432, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 69cae3fbc864c9f6c8851516dfc9bb8b828fbd020000001000): (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_133_27/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 0 with max_rows_to_read = 8230): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 16. ./src/IO/ReadHelpers.h:117: DB::SerializationLowCardinality::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f697089 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:61: DB::SerializationNamed::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6c06fb 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:730: DB::SerializationTuple::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f7e8a8b 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:293: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f5ae089 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:452: DB::SerializationMap::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6b6e8e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:290: DB::MergeTreeReaderCompact::readPrefix(DB::NameAndTypePair const&, std::shared_ptr const&, std::shared_ptr&, std::function const&) @ 0x0000000039e8f707 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:274: DB::MergeTreeReaderCompact::readPrefix(unsigned long, DB::MergeTreeReaderStream&) @ 0x0000000039e8ef62 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:52: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed659b 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.275285 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.62 MiB (attempt to allocate chunk of 1.27 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_133_27/data.bin (position: 404432, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 69cae3fbc864c9f6c8851516dfc9bb8b828fbd020000001000): (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_133_27/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 0 with max_rows_to_read = 8230): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 16. ./src/IO/ReadHelpers.h:117: DB::SerializationLowCardinality::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f697089 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:61: DB::SerializationNamed::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6c06fb 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:730: DB::SerializationTuple::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f7e8a8b 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:293: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f5ae089 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:452: DB::SerializationMap::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6b6e8e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:290: DB::MergeTreeReaderCompact::readPrefix(DB::NameAndTypePair const&, std::shared_ptr const&, std::shared_ptr&, std::function const&) @ 0x0000000039e8f707 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:274: DB::MergeTreeReaderCompact::readPrefix(unsigned long, DB::MergeTreeReaderStream&) @ 0x0000000039e8ef62 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:52: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed659b 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.279179 [ 3728 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.43 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_142_7/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.282823 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.43 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_142_7/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.437586 [ 17376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.438774 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.452141 [ 17376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.453225 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.616100 [ 10170 ] {704f3354-bb6a-4455-9f55-f0a558d85195} executeQuery: Code: 43. DB::Exception: Illegal type of argument 'structure' for table function 'executable': must be an identifier or string literal, but got: max_command_execution_time = 100. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37126) (comment: 02377_executable_function_settings.sql) (query 7, line 8) (in query: SELECT * from executable('JSON', 'data String', SETTINGS max_command_execution_time=100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000026758217 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:109: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr)::$_1::operator()(unsigned long, String const&) const @ 0x00000000267574e6 5. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:116: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002674f746 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:25:43.624836 [ 10170 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type of argument 'structure' for table function 'executable': must be an identifier or string literal, but got: max_command_execution_time = 100. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000026758217 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:109: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr)::$_1::operator()(unsigned long, String const&) const @ 0x00000000267574e6 5. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:116: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002674f746 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 19. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 20. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 22. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 25. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 26. ? @ 0x00007fa150622ac3 27. ? @ 0x00007fa1506b4850 2025.11.13 09:25:43.668763 [ 3912 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryMetricLogElement]: Failed to flush system log system.query_metric_log with 7 entries up to offset 5019: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.89 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037b1704e 10. ./src/Common/COW.h:293: DB::ColumnVector::cloneResized(unsigned long) const @ 0x0000000037b28bc1 11. DB::IColumn::cloneEmpty() const @ 0x000000002c156c44 12. ./build_docker/./src/Core/ColumnWithTypeAndName.cpp:21: DB::ColumnWithTypeAndName::cloneEmpty() const @ 0x000000002eb2689a 13. ./build_docker/./src/Core/Block.cpp:502: DB::Block::cloneEmpty() const @ 0x000000002eaff97e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:579: DB::MergeTreeDataPartWriterOnDisk::initOrAdjustDynamicStructureIfNeeded(DB::Block&) @ 0x0000000039bd16ae 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:177: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba565f 16. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 20. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 28. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000333e0dcc 29. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x00000000333de236 30. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba9d61 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba9b9f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:43.695527 [ 3916 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TraceLogElement]: Failed to flush system log system.trace_log with 2994 entries up to offset 92784: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.94 MiB (attempt to allocate chunk of 4.54 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 11. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 12. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 14. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 15. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 31. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:44.479290 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.53 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:44.482051 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.53 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:44.583032 [ 17376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:44.584325 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:44.590334 [ 17376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:44.591528 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:44.735570 [ 10170 ] {ee159a55-5718-4258-82ed-b95206e77deb} executeQuery: Code: 36. DB::Exception: Table function 'executable' argument is invalid 'TEST'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37126) (comment: 02377_executable_function_settings.sql) (query 8, line 9) (in query: SELECT * from executable('JSON', 'data String', 'TEST', 'TEST');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:150: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026753773 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:25:44.749284 [ 10170 ] {} TCPHandler: Code: 36. DB::Exception: Table function 'executable' argument is invalid 'TEST'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/TableFunctions/TableFunctionExecutable.cpp:150: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000026753773 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4854: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003041ef02 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5362: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b780c 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:25:45.252441 [ 3737 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 475.39 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column children): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_142_7/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 4579): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:45.255005 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 475.39 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column children): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_142_7/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 4579): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:45.313740 [ 18816 ] {} ExternalDictionariesLoader: Could not load external dictionary '1119b8f4-92d2-4582-bb09-e8200cde5e0e', next update is scheduled at 2025-11-13 09:25:50: Code: 60. DB::Exception: Unknown table expression identifier 'test_9hufdy9z.dict_data' in scope SELECT key, v0, v1, v2, v3, v4 FROM test_9hufdy9z.dict_data. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000002702efa8 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x000000002702e915 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0a87 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:45.461473 [ 3730 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.13 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_133_27/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 2 with max_rows_to_read = 4468): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037acb88e 12. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037c84131 13. ./src/Columns/ColumnsCommon.h:119: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037adf477 14. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037adf30e 15. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:268: DB::ColumnLowCardinality::insertRangeFromDictionaryEncodedColumn(DB::IColumn const&, DB::IColumn const&) @ 0x0000000037540706 16. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:612: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69cda4 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 27. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:45.464283 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.13 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_133_27/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 2 with max_rows_to_read = 4468): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037acb88e 12. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037c84131 13. ./src/Columns/ColumnsCommon.h:119: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037adf477 14. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037adf30e 15. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:268: DB::ColumnLowCardinality::insertRangeFromDictionaryEncodedColumn(DB::IColumn const&, DB::IColumn const&) @ 0x0000000037540706 16. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:612: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69cda4 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 27. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.345359 [ 10170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.347249 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.400713 [ 3738 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 495.29 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.401750 [ 3730 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 496.41 MiB (attempt to allocate chunk of 1.11 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_142_7/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 1 with max_rows_to_read = 8888): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.403586 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 495.29 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.404563 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 496.41 MiB (attempt to allocate chunk of 1.11 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_142_7/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 1 with max_rows_to_read = 8888): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.408017 [ 3739 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_89_95_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 493.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_93_93_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 7): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.411252 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_89_95_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 493.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_93_93_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 7): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.466505 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1171 entries up to offset 465902: Code: 241. DB::Exception: (total) memory limit exceeded: would use 500.79 MiB (attempt to allocate chunk of 4.38 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 10. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 11. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 12. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 13. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 27. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 28. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x000000003335e7be 29. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba3381 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba31bf 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.532019 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.28 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.534822 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.28 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:46.616011 [ 16132 ] {e95cd6b8-968e-4264-964d-9da359f2af3e} executeQuery: Code: 469. DB::Exception: Constraint `c` for table test_15.default_constraints (26d4b1b1-c70e-4a82-bcf4-208b074cddb4) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37320) (comment: 01286_constraints_on_default.sql) (query 3, line 9) (in query: INSERT INTO default_constraints (x) SELECT number FROM system.numbers LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:46.642398 [ 16132 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table test_15.default_constraints (26d4b1b1-c70e-4a82-bcf4-208b074cddb4) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:25:46.754430 [ 16132 ] {d95b9ca5-1b50-4168-a690-bc6dfb77e374} executeQuery: Code: 469. DB::Exception: Constraint `c` for table test_15.default_constraints (26d4b1b1-c70e-4a82-bcf4-208b074cddb4) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37320) (comment: 01286_constraints_on_default.sql) (query 4, line 10) (in query: INSERT INTO default_constraints (x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:46.772086 [ 16132 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table test_15.default_constraints (26d4b1b1-c70e-4a82-bcf4-208b074cddb4) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:47.209713 [ 19620 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:47.383962 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 415.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:47.385133 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 415.80 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:48.254737 [ 16132 ] {88f58a63-50b3-4fec-a6ee-5740dfb2f50e} executeQuery: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_393684d0-69d1-48d0-b87c-4262eb31b039` (393684d0-69d1-48d0-b87c-4262eb31b039) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37320) (comment: 01286_constraints_on_default.sql) (query 9, line 25) (in query: INSERT INTO default_constraints (x) SELECT number FROM system.numbers LIMIT 5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:25:48.280386 [ 16132 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_393684d0-69d1-48d0-b87c-4262eb31b039` (393684d0-69d1-48d0-b87c-4262eb31b039) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:25:48.356900 [ 18403 ] {bbeb2c0c-e421-4483-91e5-a352d992d961} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.58 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37306) (comment: 03275_matview_with_union.sql) (query 9, line 76) (in query: INSERT INTO src SELECT toDateTime('2020-10-01 00:00:00') + number, number % 100, number from numbers(1000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 2025.11.13 09:25:48.388092 [ 16132 ] {17c2ce9a-d9b9-4dbe-b36a-1cf582ae4d94} executeQuery: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_393684d0-69d1-48d0-b87c-4262eb31b039` (393684d0-69d1-48d0-b87c-4262eb31b039) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37320) (comment: 01286_constraints_on_default.sql) (query 10, line 26) (in query: INSERT INTO default_constraints (x) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:48.404604 [ 16132 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c` for table _temporary_and_external_tables.`_tmp_393684d0-69d1-48d0-b87c-4262eb31b039` (393684d0-69d1-48d0-b87c-4262eb31b039) is violated at row 5. Expression: (y < 5). Column values: y = 5. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, unsigned long&&, String&&, String&) @ 0x000000002f6d2847 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000003badaebe 5. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 12. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 13. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:25:48.413078 [ 18403 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.58 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:25:48.543828 [ 3739 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.33 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_142_7/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 4579): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:48.546272 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.33 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_142_7/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 4579): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:49.351787 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 468.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:49.354520 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 468.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:49.475193 [ 3729 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 428.67 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:49.478220 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_147_8}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 428.67 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:49.490732 [ 16693 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:49.493736 [ 16693 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:49.609773 [ 3732 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.65 MiB (attempt to allocate chunk of 2.42 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000377819cd 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 21. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 23. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 24. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 25. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375e8ff1 27. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 28. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 30. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:49.612544 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.65 MiB (attempt to allocate chunk of 2.42 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000377819cd 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 21. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 23. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 24. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 25. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375e8ff1 27. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 28. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 30. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:49.886028 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_233_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.57 MiB (attempt to allocate chunk of 1.19 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:49.889312 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_233_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.57 MiB (attempt to allocate chunk of 1.19 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:50.405191 [ 3735 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.40 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:50.407891 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_137_28}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.40 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:50.611862 [ 18403 ] {6167fe96-b0b5-4eff-a21f-ae6b2863a78f} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 428.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37384) (comment: 02377_optimize_sorting_by_input_stream_properties.sql) (query 4, line 5) (in query: INSERT INTO optimize_sorting VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 31. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 2025.11.13 09:25:50.633154 [ 18403 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 428.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 31. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 2025.11.13 09:25:50.692419 [ 16132 ] {a68d41e9-afec-4fb1-be68-b3e9aeaaf863} executeQuery: Code: 215. DB::Exception: Column c0 is not under aggregate function and not in GROUP BY keys. In query SELECT * FROM (SELECT '' AS c0, '' AS c1, '' AS c2, '' AS c3, '' AS c4, '' AS c5, '' AS c6, '' AS c7, '' AS c8, '' AS c9, '' AS c10, '' AS c11, '' AS c12, '' AS c13, '' AS c14, '' AS c15, '' AS c16, '' AS c17, '' AS c18, '' AS c19, '' AS c20, '' AS c21, '' AS c22, '' AS c23, '' AS c24, '' AS c25, '' AS c26, '' AS c27, '' AS c28, '' AS c29, '' AS c30, '' AS c31, '' AS c32, '' AS c33, '' AS c34, '' AS c35, '' AS c36, '' AS c37, '' AS c38, '' AS c39, '' AS c40, '' AS c41, '' AS c42, '' AS c43, '' AS c44, '' AS c45, '' AS c46, '' AS c47, '' AS c48, '' AS c49, '' AS c50, '' AS c51, '' AS c52, '' AS c53, '' AS c54, '' AS c55, '' AS c56, '' AS c57, '' AS c58, '' AS c59, '' AS c60, '' AS c61, '' AS c62, '' AS c63, '' AS c64) GROUP BY ALL WITH CUBE. (NOT_AN_AGGREGATE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37406) (comment: 03253_group_by_cube_too_many_keys.sql) (query 1, line 1) (in query: SELECT * FROM (SELECT '' AS c0, '' AS c1, '' AS c2, '' AS c3, '' AS c4, '' AS c5, '' AS c6, '' AS c7, '' AS c8, '' AS c9, '' AS c10, '' AS c11, '' AS c12, '' AS c13, '' AS c14, '' AS c15, '' AS c16, '' AS c17, '' AS c18, '' AS c19, '' AS c20, '' AS c21, '' AS c22, '' AS c23, '' AS c24, '' AS c25, '' AS c26, '' AS c27, '' AS c28, '' AS c29, '' AS c30, '' AS c31, '' AS c32, '' AS c33, '' AS c34, '' AS c35, '' AS c36, '' AS c37, '' AS c38, '' AS c39, '' AS c40, '' AS c41, '' AS c42, '' AS c43, '' AS c44, '' AS c45, '' AS c46, '' AS c47, '' AS c48, '' AS c49, '' AS c50, '' AS c51, '' AS c52, '' AS c53, '' AS c54, '' AS c55, '' AS c56, '' AS c57, '' AS c58, '' AS c59, '' AS c60, '' AS c61, '' AS c62, '' AS c63, '' AS c64) GROUP BY ALL WITH CUBE;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030557281 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003055485d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:25:50.716223 [ 16132 ] {} TCPHandler: Code: 215. DB::Exception: Column c0 is not under aggregate function and not in GROUP BY keys. In query SELECT * FROM (SELECT '' AS c0, '' AS c1, '' AS c2, '' AS c3, '' AS c4, '' AS c5, '' AS c6, '' AS c7, '' AS c8, '' AS c9, '' AS c10, '' AS c11, '' AS c12, '' AS c13, '' AS c14, '' AS c15, '' AS c16, '' AS c17, '' AS c18, '' AS c19, '' AS c20, '' AS c21, '' AS c22, '' AS c23, '' AS c24, '' AS c25, '' AS c26, '' AS c27, '' AS c28, '' AS c29, '' AS c30, '' AS c31, '' AS c32, '' AS c33, '' AS c34, '' AS c35, '' AS c36, '' AS c37, '' AS c38, '' AS c39, '' AS c40, '' AS c41, '' AS c42, '' AS c43, '' AS c44, '' AS c45, '' AS c46, '' AS c47, '' AS c48, '' AS c49, '' AS c50, '' AS c51, '' AS c52, '' AS c53, '' AS c54, '' AS c55, '' AS c56, '' AS c57, '' AS c58, '' AS c59, '' AS c60, '' AS c61, '' AS c62, '' AS c63, '' AS c64) GROUP BY ALL WITH CUBE. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000030557281 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000305562f9 6. ./build_docker/./src/Analyzer/ValidationUtils.cpp:359: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000003055485d 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5803: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303ffe51 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:25:51.846090 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 460.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:51.848752 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 460.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:52.174734 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_233_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.43 MiB (attempt to allocate chunk of 1.62 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:52.177235 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_233_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.43 MiB (attempt to allocate chunk of 1.62 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:52.179867 [ 2997 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:52.181540 [ 2997 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:52.300064 [ 16198 ] {d457fe34-2fa0-466d-9563-89b20c18d116} executeQuery: Code: 60. DB::Exception: Table test_rr6dqsl7.kill_mutation_r2 does not exist. Maybe you meant test_rr6dqsl7.kill_mutation_r1?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46558) (comment: 00834_kill_mutation_replicated_zookeeper.sh) (query 1, line 1) (in query: SYSTEM SYNC REPLICA kill_mutation_r2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1258: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003390a222 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x00000000338e099f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:25:52.371023 [ 2997 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 411.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:52.372666 [ 2997 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 411.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:52.407083 [ 16198 ] {} TCPHandler: Code: 60. DB::Exception: Table test_rr6dqsl7.kill_mutation_r2 does not exist. Maybe you meant test_rr6dqsl7.kill_mutation_r1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1258: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x000000003390a222 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x00000000338e099f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:25:52.789713 [ 19620 ] {6df614b2-a65e-46b8-912f-5c50614e7040} executeQuery: Code: 80. DB::Exception: Create table with statistics is now disabled. Turn on allow_experimental_statistics. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46522) (comment: 02864_statistics_ddl.sql) (query 4, line 11) (in query: -- Error case: Can't create statistics when allow_experimental_statistics = 0 CREATE TABLE tab (col Float64 STATISTICS(tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:713: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ce78f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:25:52.801692 [ 19620 ] {} TCPHandler: Code: 80. DB::Exception: Create table with statistics is now disabled. Turn on allow_experimental_statistics. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:713: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ce78f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:25:53.701963 [ 3729 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_238_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.94 MiB (attempt to allocate chunk of 2.53 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:53.705254 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_238_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.94 MiB (attempt to allocate chunk of 2.53 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:53.710096 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.41 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:53.763942 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_113_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.41 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:53.964553 [ 19620 ] {85a283b2-c5ea-4ec3-a3a7-bc06e2799624} executeQuery: Code: 80. DB::Exception: Unknown statistics type: no_statistics_type. Supported statistics types are 'countmin', 'minmax', 'tdigest' and 'uniq'. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46522) (comment: 02864_statistics_ddl.sql) (query 6, line 16) (in query: -- Error case: Unknown statistics types are rejected CREATE TABLE tab (col Float64 STATISTICS(no_statistics_type)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:54: DB::stringToStatisticsType(String) @ 0x0000000038432838 5. ./build_docker/./src/Storages/StatisticsDescription.cpp:177: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000038436165 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:715: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ccffa 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:25:53.977635 [ 19620 ] {} TCPHandler: Code: 80. DB::Exception: Unknown statistics type: no_statistics_type. Supported statistics types are 'countmin', 'minmax', 'tdigest' and 'uniq'. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:54: DB::stringToStatisticsType(String) @ 0x0000000038432838 5. ./build_docker/./src/Storages/StatisticsDescription.cpp:177: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000038436165 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:715: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ccffa 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:25:54.594640 [ 6078 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:54.596425 [ 6078 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:54.862768 [ 19620 ] {487ded16-d39a-4702-92a7-39d1334a10be} executeQuery: Code: 80. DB::Exception: Column col already contains statistics type tdigest. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46522) (comment: 02864_statistics_ddl.sql) (query 7, line 19) (in query: -- Error case: The same statistics type can't exist more than once on a column CREATE TABLE tab (col Float64 STATISTICS(tdigest, tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008c2a26d 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:179: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x000000003843660a 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:715: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ccffa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:25:54.891878 [ 19620 ] {} TCPHandler: Code: 80. DB::Exception: Column col already contains statistics type tdigest. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000008c2a26d 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:179: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x000000003843660a 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:715: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000329ccffa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000329d2539 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fc3dd 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:25:55.340194 [ 17697 ] {} ExternalDictionariesLoader: Could not load external dictionary '1119b8f4-92d2-4582-bb09-e8200cde5e0e', next update is scheduled at 2025-11-13 09:26:07: Code: 60. DB::Exception: Unknown table expression identifier 'test_9hufdy9z.dict_data' in scope SELECT key, v0, v1, v2, v3, v4 FROM test_9hufdy9z.dict_data. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000002702efa8 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x000000002702e915 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0a87 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:55.409838 [ 3726 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_114_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 466.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:55.412624 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_114_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 466.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:55.815558 [ 16693 ] {7e51ac23-481b-4405-836c-bee8b83b5a5d} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 32 (DROP): DROP COLUMN c. Expected one of: ALTER command, token, OpeningRoundBracket: In scope SELECT formatQuery('ALTER TABLE a (DROP COLUMN b), DROP COLUMN c'). (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46594) (comment: 02982_unambiguous_alter_commands.sql) (query 5, line 6) (in query: SELECT formatQuery('ALTER TABLE a (DROP COLUMN b), DROP COLUMN c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5c6a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee4d3c7 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:25:55.827777 [ 16693 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 32 (DROP): DROP COLUMN c. Expected one of: ALTER command, token, OpeningRoundBracket: In scope SELECT formatQuery('ALTER TABLE a (DROP COLUMN b), DROP COLUMN c'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5c6a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee4d3c7 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:25:55.876876 [ 3728 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_89_95_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_89_89_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 6): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:55.879004 [ 16693 ] {72ee1509-107d-4d83-9707-0e0fde671101} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 30 ((): (DROP COLUMN c). Expected one of: ALTER command, ADD COLUMN, RENAME COLUMN, MATERIALIZE COLUMN, DROP PARTITION, DROP PART, FORGET PARTITION, DROP DETACHED PARTITION, DROP DETACHED PART, DROP COLUMN, CLEAR COLUMN, ADD INDEX, DROP INDEX, CLEAR INDEX, MATERIALIZE INDEX, ADD STATISTICS, MODIFY STATISTICS, DROP STATISTICS, CLEAR STATISTICS, MATERIALIZE STATISTICS, ADD PROJECTION, DROP PROJECTION, CLEAR PROJECTION, MATERIALIZE PROJECTION, MOVE PART, MOVE PARTITION, ADD CONSTRAINT, DROP CONSTRAINT, DETACH PARTITION, DETACH PART, ATTACH PARTITION, REPLACE PARTITION, ATTACH PART, FETCH PARTITION, FETCH PART, FREEZE, UNFREEZE, UNLOCK SNAPSHOT, MODIFY COLUMN, ALTER COLUMN, MODIFY ORDER BY, MODIFY SAMPLE BY, REMOVE SAMPLE BY, DELETE, UPDATE, COMMENT COLUMN, MODIFY TTL, REMOVE TTL, MATERIALIZE TTL, MODIFY SETTING, RESET SETTING, MODIFY QUERY, MODIFY SQL SECURITY, MODIFY DEFINER, MODIFY REFRESH, MODIFY COMMENT, APPLY DELETED MASK: In scope SELECT formatQuery('ALTER TABLE a DROP COLUMN b, (DROP COLUMN c)'). (SYNTAX_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46594) (comment: 02982_unambiguous_alter_commands.sql) (query 6, line 7) (in query: SELECT formatQuery('ALTER TABLE a DROP COLUMN b, (DROP COLUMN c)');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5c6a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee4d3c7 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:25:55.879233 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_89_95_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_89_89_0/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 6): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:55.890048 [ 16693 ] {} TCPHandler: Code: 62. DB::Exception: Syntax error: failed at position 30 ((): (DROP COLUMN c). Expected one of: ALTER command, ADD COLUMN, RENAME COLUMN, MATERIALIZE COLUMN, DROP PARTITION, DROP PART, FORGET PARTITION, DROP DETACHED PARTITION, DROP DETACHED PART, DROP COLUMN, CLEAR COLUMN, ADD INDEX, DROP INDEX, CLEAR INDEX, MATERIALIZE INDEX, ADD STATISTICS, MODIFY STATISTICS, DROP STATISTICS, CLEAR STATISTICS, MATERIALIZE STATISTICS, ADD PROJECTION, DROP PROJECTION, CLEAR PROJECTION, MATERIALIZE PROJECTION, MOVE PART, MOVE PARTITION, ADD CONSTRAINT, DROP CONSTRAINT, DETACH PARTITION, DETACH PART, ATTACH PARTITION, REPLACE PARTITION, ATTACH PART, FETCH PARTITION, FETCH PART, FREEZE, UNFREEZE, UNLOCK SNAPSHOT, MODIFY COLUMN, ALTER COLUMN, MODIFY ORDER BY, MODIFY SAMPLE BY, REMOVE SAMPLE BY, DELETE, UPDATE, COMMENT COLUMN, MODIFY TTL, REMOVE TTL, MATERIALIZE TTL, MODIFY SETTING, RESET SETTING, MODIFY QUERY, MODIFY SQL SECURITY, MODIFY DEFINER, MODIFY REFRESH, MODIFY COMMENT, APPLY DELETED MASK: In scope SELECT formatQuery('ALTER TABLE a DROP COLUMN b, (DROP COLUMN c)'). (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x0000000008c8a7de 3. ./build_docker/./src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5c6a 4. ./build_docker/./src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003e2f5db1 5. DB::(anonymous namespace)::FunctionFormatQuery::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee4d3c7 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:25:57.278478 [ 2997 ] {6467c19a-8a9f-4ad2-bcda-55f1a62547d1} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46636) (comment: 02916_set_formatting.sql) (query 8, line 12) (in query: DROP VIEW v1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:25:57.299265 [ 2997 ] {} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000038356487 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:25:57.370083 [ 6078 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:58.282403 [ 6078 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:58.283657 [ 6078 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:58.392331 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_114_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:58.395551 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_114_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:25:58.625792 [ 19620 ] {d77a0e8d-8d36-40a3-822f-3fb12ae0b170} executeQuery: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46522) (comment: 02864_statistics_ddl.sql) (query 25, line 36) (in query: CREATE TABLE tab (col Enum('hello', 'world') STATISTICS(tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:25:58.636794 [ 19620 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:25:59.292938 [ 6078 ] {b0c585e3-8266-428d-9d27-da94fab7af60} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46696) (comment: 02242_subcolumns_sizes.sql) (query 2, line 5) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:25:59.307406 [ 6078 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:00.213586 [ 16693 ] {507283c5-bdef-4d91-b758-148e8b93e546} executeQuery: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]). (TOO_LARGE_ARRAY_SIZE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46680) (comment: 01777_map_populate_series_ubsan.sql) (query 1, line 1) (in query: -- Should correctly throw exception about overflow: SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x000000001f3c6ccf 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x000000001f3c543d 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ee74675 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:00.223731 [ 16693 ] {} TCPHandler: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x000000001f3c6ccf 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x000000001f3c543d 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001ee74675 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:00.523074 [ 16887 ] {83135977-9b90-4137-b30f-e380b9536f14} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 422.93 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46710) (comment: 02125_lz4_compression_bug_JSONStringsEachRow.sh) (query 1, line 1) (in query: SELECT max(x) FROM file), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:26:00.545617 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_114_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.01 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:00.548760 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_114_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.01 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:00.552028 [ 16887 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 422.93 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:01.779905 [ 20389 ] {} ZooKeeperClient: Code: 999. Coordination::Exception: Session expired (fault injected on recv). (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000003a3dfd6c 3. ./src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x000000003d179be4 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:1795: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x000000003d15fa02 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:928: Coordination::ZooKeeper::receiveEvent() @ 0x000000003d15c45b 6. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:875: Coordination::ZooKeeper::receiveThread() @ 0x000000003d15aaf9 7. ./build_docker/./src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1>(Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003d175e4f 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:01.783172 [ 3592 ] {} test_rr6dqsl7.kill_mutation_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:01.786001 [ 3504 ] {} test_7.combinator_argMin_table_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:01.786525 [ 3444 ] {} test_15.partitioned_table (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:01.788868 [ 3261 ] {} test_13.replica_01108_4 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:01.789486 [ 3271 ] {} test_7.combinator_argMin_table_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:01.791808 [ 3431 ] {} test_7.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:01.792322 [ 3223 ] {} test_15.data_rep_02228 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:01.793546 [ 3561 ] {} test_1.t_mutations_nondeterministic (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:01.796593 [ 3535 ] {} test_15.table_3 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:01.799018 [ 3475 ] {} test_7.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:01.801734 [ 3605 ] {} test_9.join_inner_table (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.11.13 09:26:02.591747 [ 3482 ] {} test_7.rmt2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02446/test_7/rmt/replicas/2/log_pointer. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000f1265ec 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:697: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x000000003d0083bc 5. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:665: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000003d0075d3 6. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:284: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x000000003a238e4e 7. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000003a234405 8. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x000000003a230a02 9. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:49: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003a25a2bf 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 11. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 12. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:04.246864 [ 18700 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:04.573989 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_114_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.68 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:04.576930 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_114_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 563.68 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:05.556785 [ 16141 ] {eb002b68-0308-4868-9feb-dc287b6987e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 0, should be 1: In scope SELECT seriesPeriodDetectFFT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46734) (comment: 02813_series_period_detect.sql) (query 15, line 19) (in query: SELECT seriesPeriodDetectFFT();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:05.567234 [ 16141 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 0, should be 1: In scope SELECT seriesPeriodDetectFFT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:07.007804 [ 16141 ] {77a9e251-47a8-489a-aa1b-5b0479cce404} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([]). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46734) (comment: 02813_series_period_detect.sql) (query 16, line 20) (in query: SELECT seriesPeriodDetectFFT([]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a48e731 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:07.021630 [ 16141 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nothing) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([]). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a48e731 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:07.169864 [ 16141 ] {5207cff5-00dd-4fa2-a89f-8204002896bf} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nullable(Nothing)) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([NULL, NULL, NULL]). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46734) (comment: 02813_series_period_detect.sql) (query 17, line 21) (in query: SELECT seriesPeriodDetectFFT([NULL, NULL, NULL]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a48e731 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:07.180984 [ 16141 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nullable(Nothing)) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([NULL, NULL, NULL]). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a48e731 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:07.291343 [ 16141 ] {632aeeb6-6a36-46ef-8c98-4eea9dbc0d96} executeQuery: Code: 44. DB::Exception: Illegal column Array(Nullable(UInt8)) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([10, 20, 30, 10, 202, 30, NULL]). (ILLEGAL_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46734) (comment: 02813_series_period_detect.sql) (query 18, line 22) (in query: SELECT seriesPeriodDetectFFT([10, 20, 30, 10, 202, 30, NULL]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a48e731 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:07.375115 [ 16141 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column Array(Nullable(UInt8)) of first argument of function seriesPeriodDetectFFT: In scope SELECT seriesPeriodDetectFFT([10, 20, 30, 10, 202, 30, NULL]). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. DB::FunctionSeriesPeriodDetectFFT::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a48e731 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:08.074808 [ 3739 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_114_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 570.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:08.077358 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_57_114_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 570.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:10.521244 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 486.70 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:10.533497 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 486.70 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:10.540576 [ 16720 ] {} ExternalDictionariesLoader: Could not load external dictionary '1119b8f4-92d2-4582-bb09-e8200cde5e0e', next update is scheduled at 2025-11-13 09:26:29: Code: 60. DB::Exception: Unknown table expression identifier 'test_9hufdy9z.dict_data' in scope SELECT key, v0, v1, v2, v3, v4 FROM test_9hufdy9z.dict_data. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000002702efa8 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x000000002702e915 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0a87 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:11.140098 [ 16233 ] {242a19c0-1880-4b66-ad95-87d7131a7125} executeQuery: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47820) (comment: 03261_optimize_rewrite_array_exists_to_has_crash.sql) (query 3, line 4) (in query: SELECT 1 FROM rewrite INNER JOIN rewrite AS y ON ( SELECT 1 ) INNER JOIN rewrite AS z ON 1 SETTINGS optimize_rewrite_array_exists_to_has=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:529: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000032d07b72 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2042: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c76c5d 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:26:11.192740 [ 16233 ] {} TCPHandler: Code: 48. DB::Exception: JOIN ON constant supported only with join algorithm 'hash'. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Planner/PlannerJoinsLogical.cpp:529: DB::buildJoinStepLogical(DB::Block const&, DB::Block const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x0000000032d07b72 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2042: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x0000000032c76c5d 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2291: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4c402 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:26:11.252290 [ 16215 ] {b92d1e56-2dc6-49b6-8030-359c7b655f38} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(1, 3600 - timeZoneOffset(CAST('2024-05-06 12:00:00', 'DateTime'))) SETTINGS session_timezone = 'Europe/Lisbon'. (ILLEGAL_DIVISION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44074) (comment: 00265_http_content_type_format_timezone.sh) (in query: SELECT intDiv(1, (3600-timeZoneOffset('2024-05-06 12:00:00'::DateTime))) SETTINGS session_timezone = 'Europe/Lisbon' ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x000000000f1172d6 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011de8a55 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000011de7930 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011dd3b3e 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011dd0b06 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011dc7592 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011dc1b4d 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011dbee0d 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 2025.11.13 09:26:11.364180 [ 16215 ] {b92d1e56-2dc6-49b6-8030-359c7b655f38} DynamicQueryHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(1, 3600 - timeZoneOffset(CAST('2024-05-06 12:00:00', 'DateTime'))) SETTINGS session_timezone = 'Europe/Lisbon'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x000000000f1172d6 5. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011de8a55 6. auto DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)::operator(), DB::DataTypeNumber>(auto const&, auto const&) const @ 0x0000000011de7930 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011dd3b3e 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000011dd0b06 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x0000000011dc7592 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011dc1b4d 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011dbee0d 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 13. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:12.283405 [ 16344 ] {a0548187-c551-43d6-81ae-e4139c27844e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43700) (comment: 02012_zookeeper_changed_enum_type.sql) (in query: DROP DATABASE IF EXISTS test_w3wypmbm SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:26:12.298213 [ 16344 ] {a0548187-c551-43d6-81ae-e4139c27844e} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:13.343950 [ 17228 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 610.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:13.347463 [ 17228 ] {} DynamicQueryHandler: Cannot send exception to client: Code: 241. DB::Exception: (total) memory limit exceeded: would use 607.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./build_docker/./src/Server/HTTPHandler.cpp:623: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace72e6 14. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:13.769820 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 610.81 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:13.773046 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 610.81 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:14.298285 [ 16215 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:14.490500 [ 3731 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_138_29} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 605.04 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:14.494381 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_138_29}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 605.04 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:15.308018 [ 17383 ] {e1bb128f-e700-489b-87ed-fdaed423acbe} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:54348) (comment: 03208_multiple_joins_with_storage_join.sql) (in query: DROP DATABASE IF EXISTS test_jg056y6j SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:26:15.318565 [ 17383 ] {e1bb128f-e700-489b-87ed-fdaed423acbe} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:15.710366 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.81 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:15.713861 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.81 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:16.368303 [ 19606 ] {29a2a1d9-51fd-42c6-b07a-80d35dd6f83c} executeQuery: Code: 705. DB::Exception: Table data_02716_1 is not empty. (TABLE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47824) (comment: 02716_drop_if_empty.sql) (query 11, line 16) (in query: DROP TABLE IF EMPTY data_02716_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:154: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6c93d 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:26:16.383773 [ 19606 ] {} TCPHandler: Code: 705. DB::Exception: Table data_02716_1 is not empty. (TABLE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:154: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6c93d 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 10. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 11. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 2025.11.13 09:26:16.688638 [ 16233 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:16.691998 [ 16233 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:16.698967 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:16.700964 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:16.723883 [ 16233 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:16.750557 [ 3733 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_243_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.31 MiB (attempt to allocate chunk of 1.11 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_243_243_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1087): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:16.777726 [ 16233 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:16.779116 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_243_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.31 MiB (attempt to allocate chunk of 1.11 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_243_243_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1087): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:17.587882 [ 16233 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:18.240129 [ 17385 ] {8066bef5-9931-4dc1-a5c9-5591474ec452} executeQuery: Code: 60. DB::Exception: Table test_7.test_02155_csv does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47932) (comment: 02155_csv_with_strings_with_slash.sh) (query 1, line 1) (in query: INSERT INTO test_02155_csv SETTINGS input_format_null_as_default = 1, format_csv_allow_single_quotes=1 FORMAT CSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:18.269204 [ 17385 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.test_02155_csv does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:18.317915 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_243_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.07 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:18.321773 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_243_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.07 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:18.340168 [ 4170 ] {864ed3b0-106f-4200-b959-d1fad917aa1e} executeQuery: Code: 60. DB::Exception: Table test_1.kill_mutation does not exist. Maybe you meant test_rr6dqsl7.kill_mutation_r1?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47946) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: INSERT INTO kill_mutation VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:18.364052 [ 4170 ] {} TCPHandler: Code: 60. DB::Exception: Table test_1.kill_mutation does not exist. Maybe you meant test_rr6dqsl7.kill_mutation_r1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:18.406489 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.07 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:18.410647 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.07 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:18.500600 [ 19606 ] {8ba862b9-0257-479d-950c-b691d9ee3a01} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02716_drop_if_empty.sql) (in query: /* ddl_entry=query-0000000202 */ TRUNCATE TABLE test_11.data_02716_1 SYNC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9194: DB::MergeTreeData::createEmptyPart(DB::MergeTreePartInfo&, DB::MergeTreePartition const&, String const&, std::shared_ptr const&) @ 0x0000000039964dcb 24. ./build_docker/./src/Storages/StorageMergeTree.cpp:1912: DB::createEmptyDataParts(DB::MergeTreeData&, std::vector>&, std::shared_ptr const&) @ 0x000000003a4f801b 25. ./build_docker/./src/Storages/StorageMergeTree.cpp:1987: DB::StorageMergeTree::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003a4fe4b9 26. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 27. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 28. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 29. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 2025.11.13 09:26:18.550866 [ 19606 ] {8ba862b9-0257-479d-950c-b691d9ee3a01} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47824) (comment: 02716_drop_if_empty.sql) (query 12, line 17) (in query: TRUNCATE TABLE data_02716_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9194: DB::MergeTreeData::createEmptyPart(DB::MergeTreePartInfo&, DB::MergeTreePartition const&, String const&, std::shared_ptr const&) @ 0x0000000039964dcb 24. ./build_docker/./src/Storages/StorageMergeTree.cpp:1912: DB::createEmptyDataParts(DB::MergeTreeData&, std::vector>&, std::shared_ptr const&) @ 0x000000003a4f801b 25. ./build_docker/./src/Storages/StorageMergeTree.cpp:1987: DB::StorageMergeTree::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003a4fe4b9 26. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 27. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 28. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 29. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 2025.11.13 09:26:18.633072 [ 19606 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:9194: DB::MergeTreeData::createEmptyPart(DB::MergeTreePartInfo&, DB::MergeTreePartition const&, String const&, std::shared_ptr const&) @ 0x0000000039964dcb 24. ./build_docker/./src/Storages/StorageMergeTree.cpp:1912: DB::createEmptyDataParts(DB::MergeTreeData&, std::vector>&, std::shared_ptr const&) @ 0x000000003a4f801b 25. ./build_docker/./src/Storages/StorageMergeTree.cpp:1987: DB::StorageMergeTree::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000003a4fe4b9 26. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6bd79 27. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 28. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 29. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 2025.11.13 09:26:19.534656 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_243_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.26 MiB (attempt to allocate chunk of 1.39 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:19.543786 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_243_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.26 MiB (attempt to allocate chunk of 1.39 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:19.632723 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.94 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:19.640674 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 484.94 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:19.698634 [ 17385 ] {a21d3925-288d-4006-bdec-23feab1466a7} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_02155_csv' in scope SELECT * FROM test_02155_csv. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47968) (comment: 02155_csv_with_strings_with_slash.sh) (query 1, line 1) (in query: SELECT * FROM test_02155_csv), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:26:19.731849 [ 17385 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_02155_csv' in scope SELECT * FROM test_02155_csv. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:26:19.935469 [ 16344 ] {a10a2dcd-5e07-44ab-9e5e-b766ef136dbd} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.34 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47844) (comment: 00945_bloom_filter_index.sql) (query 10, line 15) (in query: SELECT COUNT() FROM single_column_bloom_filter WHERE i32 IN (1, 2) SETTINGS max_rows_to_read = 6;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:26:19.954217 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 11 entries up to offset 2220: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.49 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:20.000194 [ 16344 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.34 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:20.181149 [ 17227 ] {2664a10b-c957-4b4e-8cc1-aec82518697c} executeQuery: Code: 60. DB::Exception: Table test_1.kill_mutation does not exist. Maybe you meant test_rr6dqsl7.kill_mutation_r1?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47996) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: INSERT INTO kill_mutation VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:20.202596 [ 17227 ] {} TCPHandler: Code: 60. DB::Exception: Table test_1.kill_mutation does not exist. Maybe you meant test_rr6dqsl7.kill_mutation_r1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:21.341814 [ 16233 ] {900bf8cf-13d3-42bd-b49c-5250759b3976} executeQuery: Code: 60. DB::Exception: Table test_7.test_02155_csv does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43566) (comment: 02155_csv_with_strings_with_slash.sh) (query 1, line 1) (in query: TRUNCATE TABLE test_02155_csv), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:26:21.468695 [ 16233 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.test_02155_csv does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:26:21.652570 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:21.654307 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:22.176781 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.78 MiB (attempt to allocate chunk of 2.15 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:22.179776 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.78 MiB (attempt to allocate chunk of 2.15 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:22.188829 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 487.56 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:22.191949 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 487.56 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:22.248726 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 1981 entries up to offset 301832: Code: 241. DB::Exception: (total) memory limit exceeded: would use 490.64 MiB (attempt to allocate chunk of 4.15 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:22.880464 [ 3732 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.80 MiB (attempt to allocate chunk of 1.38 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_138_29/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 2 with max_rows_to_read = 4929): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 16. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 18. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:22.887510 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.80 MiB (attempt to allocate chunk of 1.38 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_138_29/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 2 with max_rows_to_read = 4929): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 16. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 18. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:22.972347 [ 4170 ] {85b8c876-295b-4710-8ec0-6ea8febe0b9d} executeQuery: Code: 60. DB::Exception: Table test_7.test_02155_csv does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43632) (comment: 02155_csv_with_strings_with_slash.sh) (query 1, line 1) (in query: INSERT INTO test_02155_csv SETTINGS format_csv_allow_single_quotes = 1, input_format_null_as_default = 0 FORMAT CSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:22.995181 [ 4170 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.test_02155_csv does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:23.066560 [ 17227 ] {c144300a-65c9-4339-bd30-8b48c3bc1ec5} executeQuery: Code: 60. DB::Exception: Could not find table: kill_mutation. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43634) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: ALTER TABLE kill_mutation DELETE WHERE toUInt32(s) = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:26:23.086074 [ 17227 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: kill_mutation. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:26:23.349190 [ 3724 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.40 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:23.354195 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.40 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:24.035851 [ 3727 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.68 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column value8): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_238_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9253): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:24.039192 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.68 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column value8): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_238_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9253): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:24.100074 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:24.102382 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:24.128702 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:24.130851 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:24.209426 [ 17385 ] {d4d6de7c-be8d-4161-9aac-e8c20e761072} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.16 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43618) (comment: 01641_memory_tracking_insert_optimize.sql) (query 7, line 14) (in query: insert into data_01641 select number, toString(number) from numbers(120000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:26:24.249592 [ 17385 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.16 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:26:24.833991 [ 3731 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:24.839753 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 478.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:24.895431 [ 3739 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.67 MiB (attempt to allocate chunk of 2.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c3f 12. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:47: DB::CompressedWriteBuffer::nextImpl() @ 0x000000003dd3a5a7 13. DB::WriteBuffer::next() @ 0x0000000008c37ea1 14. ./src/IO/HashingWriteBuffer.h:63: DB::HashingWriteBuffer::nextImpl() @ 0x000000003952910e 15. DB::WriteBuffer::next() @ 0x0000000008c37ea1 16. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:146: DB::SerializationString::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f7b6721 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:126: DB::ISerialization::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5896d4 19. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:73: DB::SerializationNamed::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f6c07ec 20. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:763: DB::SerializationTuple::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f7e8f92 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 22. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:463: DB::SerializationMap::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f6b6f41 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:163: DB::MergeTreeDataPartWriterCompact::writeDataBlock(DB::Block const&, std::vector> const&) @ 0x0000000039baa888 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:210: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x0000000039ba926d 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:202: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba7015 26. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:24.898796 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.67 MiB (attempt to allocate chunk of 2.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c3f 12. ./build_docker/./src/Compression/CompressedWriteBuffer.cpp:47: DB::CompressedWriteBuffer::nextImpl() @ 0x000000003dd3a5a7 13. DB::WriteBuffer::next() @ 0x0000000008c37ea1 14. ./src/IO/HashingWriteBuffer.h:63: DB::HashingWriteBuffer::nextImpl() @ 0x000000003952910e 15. DB::WriteBuffer::next() @ 0x0000000008c37ea1 16. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:146: DB::SerializationString::serializeBinaryBulk(DB::IColumn const&, DB::WriteBuffer&, unsigned long, unsigned long) const @ 0x000000002f7b6721 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:126: DB::ISerialization::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5896d4 19. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:73: DB::SerializationNamed::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f6c07ec 20. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:763: DB::SerializationTuple::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f7e8f92 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 22. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:463: DB::SerializationMap::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f6b6f41 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:163: DB::MergeTreeDataPartWriterCompact::writeDataBlock(DB::Block const&, std::vector> const&) @ 0x0000000039baa888 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:210: DB::MergeTreeDataPartWriterCompact::writeDataBlockPrimaryIndexAndSkipIndices(DB::Block const&, std::vector> const&) @ 0x0000000039ba926d 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:202: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba7015 26. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:25.274134 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.48 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:25.278437 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.48 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:25.299633 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.09 MiB (attempt to allocate chunk of 1.58 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_238_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9253): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:25.304545 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.09 MiB (attempt to allocate chunk of 1.58 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_238_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9253): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:25.415715 [ 17227 ] {98ffd288-62fe-4a26-902f-e83bd95091ce} executeQuery: Code: 60. DB::Exception: Table test_7.test_02155_csv does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43694) (comment: 02155_csv_with_strings_with_slash.sh) (query 1, line 1) (in query: DROP TABLE test_02155_csv), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:26:25.441069 [ 17227 ] {} TCPHandler: Code: 60. DB::Exception: Table test_7.test_02155_csv does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:26:26.123571 [ 3737 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.65 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_138_29/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 1 with max_rows_to_read = 8235): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.126252 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.65 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_138_29/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 1 with max_rows_to_read = 8235): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.226997 [ 18149 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.229690 [ 18149 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.321690 [ 3738 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 474.53 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.324814 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 474.53 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.565078 [ 3729 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.90 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.567439 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.90 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.748979 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.750593 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.828775 [ 3729 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.82 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:26.832107 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.82 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.322411 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.07 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_238_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 8959): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.323967 [ 3732 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.04 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.325519 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.07 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_238_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 8959): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.326256 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.04 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.331540 [ 3737 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.66 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.334559 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.66 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.521435 [ 18149 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.522779 [ 18149 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.635452 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 12 entries up to offset 2232: Code: 241. DB::Exception: (total) memory limit exceeded: would use 405.00 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.671773 [ 3726 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.31 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.674554 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.31 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.715913 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.717484 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.897277 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:27.898677 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.076573 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.078111 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.110216 [ 3736 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.112465 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.176815 [ 16889 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.393282 [ 3916 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TraceLogElement]: Failed to flush system log system.trace_log with 4220 entries up to offset 97004: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.50 MiB (attempt to allocate chunk of 4.37 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 11. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 12. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 14. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 15. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.429793 [ 3728 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_96_18} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.46 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While executing MergingSortedTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::resize_fill(unsigned long, unsigned long const&) @ 0x000000001f8785b6 12. ./build_docker/./src/Columns/ColumnVector.cpp:992: DB::ColumnVector::createWithOffsets(DB::PODArray, 63ul, 64ul> const&, DB::ColumnConst const&, unsigned long, unsigned long) const @ 0x0000000037b2e5e5 13. ./build_docker/./src/Columns/ColumnSparse.cpp:139: DB::ColumnSparse::convertToFullColumnIfSparse() const @ 0x00000000376c3532 14. ./build_docker/./src/Columns/ColumnSparse.cpp:901: DB::recursiveRemoveSparse(COW::immutable_ptr const&) @ 0x00000000376d56dc 15. ./build_docker/./src/Processors/Chunk.cpp:195: DB::convertToFullIfSparse(DB::Chunk&) @ 0x000000003b168bd5 16. ./src/Processors/Merges/Algorithms/IMergingAlgorithm.h:55: DB::MergingSortedAlgorithm::initialize(std::vector>) @ 0x000000003beb5026 17. ./src/Processors/Merges/IMergingTransform.h:121: DB::IMergingTransform::work() @ 0x00000000330e1f4d 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.432487 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_96_18}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.46 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While executing MergingSortedTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::resize_fill(unsigned long, unsigned long const&) @ 0x000000001f8785b6 12. ./build_docker/./src/Columns/ColumnVector.cpp:992: DB::ColumnVector::createWithOffsets(DB::PODArray, 63ul, 64ul> const&, DB::ColumnConst const&, unsigned long, unsigned long) const @ 0x0000000037b2e5e5 13. ./build_docker/./src/Columns/ColumnSparse.cpp:139: DB::ColumnSparse::convertToFullColumnIfSparse() const @ 0x00000000376c3532 14. ./build_docker/./src/Columns/ColumnSparse.cpp:901: DB::recursiveRemoveSparse(COW::immutable_ptr const&) @ 0x00000000376d56dc 15. ./build_docker/./src/Processors/Chunk.cpp:195: DB::convertToFullIfSparse(DB::Chunk&) @ 0x000000003b168bd5 16. ./src/Processors/Merges/Algorithms/IMergingAlgorithm.h:55: DB::MergingSortedAlgorithm::initialize(std::vector>) @ 0x000000003beb5026 17. ./src/Processors/Merges/IMergingTransform.h:121: DB::IMergingTransform::work() @ 0x00000000330e1f4d 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.558618 [ 3739 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.11 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.560982 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.11 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.644407 [ 17227 ] {cd9732a5-0ba0-4257-83e4-5acb341bd069} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column v6): (while reading from part /var/lib/clickhouse/store/525/525a729c-ba66-4768-be07-51d1c6ba294d/all_1_1_0/ in table test_vovu1gki.defaulted (525a729c-ba66-4768-be07-51d1c6ba294d) located on disk default of type local, from mark 0 with max_rows_to_read = 32768): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43708) (comment: 00568_empty_function_with_fixed_string.sql) (query 6, line 7) (in query: SELECT count(), notEmpty(v6) e FROM defaulted GROUP BY e;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./build_docker/./src/DataTypes/Serializations/SerializationFixedString.cpp:100: DB::SerializationFixedString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f648718 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c358f91 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 2025.11.13 09:26:28.684908 [ 17227 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column v6): (while reading from part /var/lib/clickhouse/store/525/525a729c-ba66-4768-be07-51d1c6ba294d/all_1_1_0/ in table test_vovu1gki.defaulted (525a729c-ba66-4768-be07-51d1c6ba294d) located on disk default of type local, from mark 0 with max_rows_to_read = 32768): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./build_docker/./src/DataTypes/Serializations/SerializationFixedString.cpp:100: DB::SerializationFixedString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f648718 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c358f91 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:28.694864 [ 16186 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.07 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.696107 [ 16186 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.07 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.676226 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.43 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:28.702810 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.43 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:29.093671 [ 3733 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.41 MiB (attempt to allocate chunk of 2.15 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:29.096815 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.41 MiB (attempt to allocate chunk of 2.15 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:29.809607 [ 3738 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.32 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:29.813054 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_145_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.32 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:29.894113 [ 16354 ] {586505c3-62e4-48e6-82ba-d5e8af6585ec} executeQuery: Code: 60. DB::Exception: Could not find table: kill_mutation. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43836) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: ALTER TABLE kill_mutation DELETE WHERE toUInt32(s) = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:26:29.911541 [ 16354 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: kill_mutation. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:26:29.924607 [ 3736 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.70 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_138_29/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 1 with max_rows_to_read = 8235): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 16. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 18. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:29.927241 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_139_30}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.70 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_138_29/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 1 with max_rows_to_read = 8235): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 16. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 18. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:30.007287 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:30.008643 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:30.064209 [ 17390 ] {17a941ca-eae7-48f2-b4c5-6cedba11dc58} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.80 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43732) (comment: 01453_fixsed_string_sort.sql) (query 11, line 14) (in query: INSERT INTO badFixedStringSort values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 2025.11.13 09:26:30.119568 [ 17390 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.80 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 2025.11.13 09:26:30.124931 [ 3733 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_142_147_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.74 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:30.127439 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_142_147_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.74 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:30.592672 [ 17253 ] {} ExternalDictionariesLoader: Could not load external dictionary '1119b8f4-92d2-4582-bb09-e8200cde5e0e', next update is scheduled at 2025-11-13 09:27:05: Code: 60. DB::Exception: Unknown table expression identifier 'test_9hufdy9z.dict_data' in scope SELECT key, v0, v1, v2, v3, v4 FROM test_9hufdy9z.dict_data. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000002702efa8 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x000000002702e915 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0a87 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:30.848236 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 425.49 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_238_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9253): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:30.850795 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_223_244_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 425.49 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_238_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9253): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:30.939633 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 425.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:31.018005 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 425.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:31.078812 [ 17227 ] {06457e9f-6ceb-4282-be46-dcecd60fcbf8} executeQuery: Code: 60. DB::Exception: Could not find table: kill_mutation. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33840) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: ALTER TABLE kill_mutation DELETE WHERE x = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:26:31.095542 [ 17227 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: kill_mutation. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:26:31.256560 [ 3726 ] {b3a70a5e-79a2-4814-8943-f51849713bdf::all_1_5_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::HashingWriteBuffer::HashingWriteBuffer(DB::WriteBuffer&, unsigned long) @ 0x00000000395272b8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:111: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc749 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:31.259479 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b3a70a5e-79a2-4814-8943-f51849713bdf::all_1_5_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.83 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::HashingWriteBuffer::HashingWriteBuffer(DB::WriteBuffer&, unsigned long) @ 0x00000000395272b8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:111: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc749 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:31.339371 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:31.369812 [ 3735 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_153_9} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.98 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_148_8/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 1 with max_rows_to_read = 8888): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:31.372317 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_153_9}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.98 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_148_8/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 1 with max_rows_to_read = 8888): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:31.491448 [ 18149 ] {3a602809-7f5d-47cd-b7dc-d7c7baa3dc2b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 1, line 4) (in query: --- aes_decrypt_mysql(string, key, block_mode[, init_vector, AAD]) -- The MySQL-compatitable encryption, only ecb, cbc and ofb modes are supported, -- just like for MySQL -- https://dev.mysql.com/doc/refman/8.0/en/encryption-functions.html#function_aes-encrypt -- https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_block_encryption_mode -- Please note that for keys that exceed mode-specific length, keys are folded in a MySQL-specific way, -- meaning that whole key is used, but effective key length is still determined by mode. -- when key doesn't exceed the default mode length, ecryption result equals with AES_encypt() ----------------------------------------------------------------------------------------- -- error cases ----------------------------------------------------------------------------------------- SELECT aes_decrypt_mysql();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:31.501334 [ 18149 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:31.570643 [ 18149 ] {2c55152b-5ac3-46a7-bf2c-27c76db84eda} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_decrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 2, line 17) (in query: SELECT aes_decrypt_mysql('aes-128-ecb');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:31.610691 [ 16186 ] {2b919b1e-b9ea-427f-9b25-4060517b2cfc} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.66 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43844) (comment: 03149_analyzer_join_projection_name.sql) (query 7, line 20) (in query: INSERT INTO db_for_dict_03149.users VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:26:31.631406 [ 18149 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_decrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:31.639568 [ 16186 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.66 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:26:31.644082 [ 3736 ] {b3a70a5e-79a2-4814-8943-f51849713bdf::all_1_8_1} TemporaryFileOnLocalDisk: Temporary path 'tmp18d71fd8-2d9c-4520-a484-f82295c958f8' does not exist in '/tmp/clickhouse/' on disk _tmp_default 2025.11.13 09:26:31.715628 [ 18149 ] {8738282c-3c37-42a4-bcb3-0e4eaa2efecc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 3, line 18) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:31.726724 [ 18149 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:31.845506 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_238_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.77 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column event_time): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_238_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9253): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c115fc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4e9f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:31.847759 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_238_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.77 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column event_time): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_223_238_2/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 9253): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c115fc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e4e9f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:32.334431 [ 3903 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryLogElement]: Failed to flush system log system.query_log with 645 entries up to offset 63610: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.08 MiB (attempt to allocate chunk of 4.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332cf2e1 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:32.613807 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_239_246_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.43 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:32.616723 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_239_246_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.43 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 12. ./build_docker/./src/Columns/ColumnString.cpp:157: DB::ColumnString::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000376e05c6 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:32.727893 [ 3736 ] {b3a70a5e-79a2-4814-8943-f51849713bdf::all_1_8_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:133: DB::TemporaryFileOnLocalDisk::write() @ 0x000000003356c8ba 18. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x0000000033562f6a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::RowsSourcesTemporaryFile::getTemporaryFileForWriting(String const&) @ 0x00000000398118a5 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1571: DB::MergePartsStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000397ec37a 21. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:32.731032 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b3a70a5e-79a2-4814-8943-f51849713bdf::all_1_8_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:133: DB::TemporaryFileOnLocalDisk::write() @ 0x000000003356c8ba 18. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x0000000033562f6a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::RowsSourcesTemporaryFile::getTemporaryFileForWriting(String const&) @ 0x00000000398118a5 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1571: DB::MergePartsStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000397ec37a 21. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:32.932232 [ 3728 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_153_9} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 403.48 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading column session_id): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_148_8/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 6962): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6f81ff 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:32.934490 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_153_9}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 403.48 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading column session_id): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_148_8/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 6962): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6f81ff 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:32.953415 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:32.954907 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.045990 [ 18149 ] {90592bb0-b176-4cfb-9d15-4b695eab94b3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_decrypt_mysql'. Expected: decryption mode string, got: UInt16: In scope SELECT aes_decrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 4, line 20) (in query: SELECT aes_decrypt_mysql(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:33.055574 [ 18149 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_decrypt_mysql'. Expected: decryption mode string, got: UInt16: In scope SELECT aes_decrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:33.426347 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_239_246_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.58 MiB (attempt to allocate chunk of 1.18 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_246_246_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1134): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.428861 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_239_246_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.58 MiB (attempt to allocate chunk of 1.18 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_246_246_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1134): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.442343 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.08 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.445588 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.08 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.809157 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.810490 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.882599 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.883795 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.908313 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.909520 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.942475 [ 17226 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:33.944324 [ 17226 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.036326 [ 16354 ] {1cbb314e-403f-4b34-a706-7464fd36d996} executeQuery: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(-678942). (CANNOT_FORMAT_DATETIME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33850) (comment: 01544_fromModifiedJulianDay.sql) (query 7, line 9) (in query: SELECT fromModifiedJulianDay(-678942);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::OrdinalDate::init(long) @ 0x000000000aeb300c 5. DB::OrdinalDate::OrdinalDate(long) @ 0x000000000aeb30f7 6. DB::GregorianDate::GregorianDate(long) @ 0x000000000aeb1cdb 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee93d51 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:34.104178 [ 16354 ] {} TCPHandler: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(-678942). (CANNOT_FORMAT_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::OrdinalDate::init(long) @ 0x000000000aeb300c 5. DB::OrdinalDate::OrdinalDate(long) @ 0x000000000aeb30f7 6. DB::GregorianDate::GregorianDate(long) @ 0x000000000aeb1cdb 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee93d51 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:34.443829 [ 17226 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.505887 [ 3733 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_153_9} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.61 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_148_8/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 1 with max_rows_to_read = 8888): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.508100 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_153_9}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.61 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_148_8/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 1 with max_rows_to_read = 8888): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.554943 [ 16355 ] {1fb9989b-cf60-4c31-825c-39ef4c43266d} executeQuery: Code: 60. DB::Exception: Could not find table: kill_mutation. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33940) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: ALTER TABLE kill_mutation DELETE WHERE x = 1 SETTINGS mutations_sync = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:26:34.568862 [ 16355 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: kill_mutation. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:26:34.624207 [ 3724 ] {b3a70a5e-79a2-4814-8943-f51849713bdf::all_1_8_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.626893 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b3a70a5e-79a2-4814-8943-f51849713bdf::all_1_8_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.628491 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_239_246_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.53 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_239_239_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1039): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.631472 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_239_246_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.53 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_239_239_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1039): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.746299 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.747606 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.774958 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.03 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.776634 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.03 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.800129 [ 3732 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_238_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.802713 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_238_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedColumnOnlyOutputStream.cpp:44: DB::MergedColumnOnlyOutputStream::MergedColumnOnlyOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, unsigned long, std::set, std::allocator>*) @ 0x000000003a0762e6 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000397cc9e2 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000397d77e9 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000397d68a0 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:34.826804 [ 18149 ] {ce1a7a45-2ca7-4e5d-9ca6-aab4ff5e8f47} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_decrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 5, line 22) (in query: SELECT aes_decrypt_mysql('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b20030b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:34.840216 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_decrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b20030b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:34.912694 [ 18149 ] {e48a77f9-5895-449f-914a-05ec572b1fee} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_decrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 6, line 23) (in query: SELECT aes_decrypt_mysql('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b20030b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:34.922856 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_decrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b20030b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:35.001225 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.002410 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.004695 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_238_6} TemporaryFileOnLocalDisk: Temporary path 'tmpe6d96527-6c7d-403b-bcbf-fa547f2febc1' does not exist in '/tmp/clickhouse/' on disk _tmp_default 2025.11.13 09:26:35.010465 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_238_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:133: DB::TemporaryFileOnLocalDisk::write() @ 0x000000003356c8ba 18. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x0000000033562f6a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::RowsSourcesTemporaryFile::getTemporaryFileForWriting(String const&) @ 0x00000000398118a5 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1571: DB::MergePartsStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000397ec37a 21. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.012577 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_238_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:133: DB::TemporaryFileOnLocalDisk::write() @ 0x000000003356c8ba 18. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x0000000033562f6a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::RowsSourcesTemporaryFile::getTemporaryFileForWriting(String const&) @ 0x00000000398118a5 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1571: DB::MergePartsStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000397ec37a 21. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.044957 [ 3727 ] {b3a70a5e-79a2-4814-8943-f51849713bdf::all_1_8_1} TemporaryFileOnLocalDisk: Temporary path 'tmpb8be04b0-da3b-4259-9068-3f13dddd90bb' does not exist in '/tmp/clickhouse/' on disk _tmp_default 2025.11.13 09:26:35.047752 [ 3727 ] {b3a70a5e-79a2-4814-8943-f51849713bdf::all_1_8_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:133: DB::TemporaryFileOnLocalDisk::write() @ 0x000000003356c8ba 18. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x0000000033562f6a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::RowsSourcesTemporaryFile::getTemporaryFileForWriting(String const&) @ 0x00000000398118a5 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1571: DB::MergePartsStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000397ec37a 21. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.050038 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {b3a70a5e-79a2-4814-8943-f51849713bdf::all_1_8_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:133: DB::TemporaryFileOnLocalDisk::write() @ 0x000000003356c8ba 18. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x0000000033562f6a 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::RowsSourcesTemporaryFile::getTemporaryFileForWriting(String const&) @ 0x00000000398118a5 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1571: DB::MergePartsStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000397ec37a 21. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 22. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.244591 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.247498 [ 17226 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.249001 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_239_246_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.76 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_239_239_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1039): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.251016 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_239_246_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.76 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_239_239_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1039): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.308645 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.98 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.311671 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.98 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.370677 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 20 entries up to offset 2252: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.15 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.464816 [ 3735 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_153_9} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.15 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.467171 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_153_9}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.15 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.494620 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.495739 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.566778 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.567888 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.576530 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.577708 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:35.946158 [ 16354 ] {7b6d4b18-6b6f-446c-b115-1c8c472bebd5} executeQuery: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(2973484). (CANNOT_FORMAT_DATETIME) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:33850) (comment: 01544_fromModifiedJulianDay.sql) (query 10, line 12) (in query: SELECT fromModifiedJulianDay(2973484);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::OrdinalDate::init(long) @ 0x000000000aeb300c 5. DB::OrdinalDate::OrdinalDate(long) @ 0x000000000aeb30f7 6. DB::GregorianDate::GregorianDate(long) @ 0x000000000aeb1cdb 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee829d0 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:35.954680 [ 16354 ] {} TCPHandler: Code: 490. DB::Exception: Value cannot be represented as date because it's out of range: In scope SELECT fromModifiedJulianDay(2973484). (CANNOT_FORMAT_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::OrdinalDate::init(long) @ 0x000000000aeb300c 5. DB::OrdinalDate::OrdinalDate(long) @ 0x000000000aeb30f7 6. DB::GregorianDate::GregorianDate(long) @ 0x000000000aeb1cdb 7. DB::ExecutableFunctionFromModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee829d0 8. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c60782 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:36.699417 [ 18149 ] {1ab26ffb-e087-4742-91de-e0022d62d737} executeQuery: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_decrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 7, line 24) (in query: SELECT aes_decrypt_mysql('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b200692 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:36.707136 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_decrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b200692 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:36.732712 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 1981 entries up to offset 306077: Code: 241. DB::Exception: (total) memory limit exceeded: would use 421.26 MiB (attempt to allocate chunk of 4.15 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:36.897662 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_238_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::WrapperGuard::WrapperGuard>(std::unique_ptr>, std::shared_ptr&&) @ 0x0000000033567da3 14. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x00000000335630c4 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::RowsSourcesTemporaryFile::getTemporaryFileForWriting(String const&) @ 0x00000000398118a5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1571: DB::MergePartsStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000397ec37a 17. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:36.899865 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_113_238_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::WrapperGuard::WrapperGuard>(std::unique_ptr>, std::shared_ptr&&) @ 0x0000000033567da3 14. ./build_docker/./src/Interpreters/TemporaryDataOnDisk.cpp:224: DB::TemporaryDataBuffer::TemporaryDataBuffer(std::shared_ptr, unsigned long) @ 0x00000000335630c4 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::RowsSourcesTemporaryFile::getTemporaryFileForWriting(String const&) @ 0x00000000398118a5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1571: DB::MergePartsStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000397ec37a 17. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14b111 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:37.067954 [ 17226 ] {de877d00-b10e-4632-823c-323fb8b0cfb5} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 421.92 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34024) (comment: 00491_shard_distributed_and_aliases_in_where_having.sql) (query 1, line 3) (in query: SELECT dummy FROM (SELECT dummy, NOT dummy AS x FROM remote('127.0.0.{2,3}', system.one) GROUP BY dummy HAVING x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003ab4ec00 15. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003ab2c32a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f2afe36 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f2923e7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 19. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:26:37.087725 [ 3726 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 447.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:37.090375 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 447.57 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:37.094658 [ 3733 ] {205b8dc2-7b75-4374-9596-7f359671c6d7::202511_1_141_28} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.22 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:37.097217 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {205b8dc2-7b75-4374-9596-7f359671c6d7::202511_1_141_28}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.22 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:37.112751 [ 5803 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:37.114015 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:37.145046 [ 17376 ] {c4101d5f-f190-4107-8bf1-abe2d7d78d40} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34052) (comment: 03167_base64_url_functions.sql) (query 1, line 4) (in query: -- incorrect number of arguments SELECT base64URLEncode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.145331 [ 18391 ] {5e9ea1a2-2be4-44ec-8fa6-93b9eb117364} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48288) (comment: 00491_shard_distributed_and_aliases_in_where_having.sql) (query 1, line 3) (in query: SELECT `__table1`.`dummy` AS `dummy` FROM `system`.`one` AS `__table1` GROUP BY `__table1`.`dummy` HAVING NOT `__table1`.`dummy`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.155842 [ 17376 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.157841 [ 18391 ] {5e9ea1a2-2be4-44ec-8fa6-93b9eb117364} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:48288). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2558: DB::TCPHandler::sendException(DB::Exception const&, bool) @ 0x000000003aecc107 7. ./build_docker/./src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x000000003aea56e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:37.167715 [ 18391 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.180934 [ 17226 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 421.92 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./src/Common/FiberStack.h:65: FiberStack::allocate() const @ 0x000000002f2e5ed2 11. ./contrib/boost/boost/context/fiber_ucontext.hpp:312: boost::context::detail::fiber_activation_record* boost::context::detail::create_fiber1>(FiberStack&, Fiber::RoutineImpl&&) @ 0x000000002f2e43ea 12. ./contrib/boost/boost/context/fiber_ucontext.hpp:449: DB::AsyncTaskExecutor::createFiber() @ 0x000000002f2e2e3d 13. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:19: DB::AsyncTaskExecutor::resume() @ 0x000000002f2e2b59 14. ./src/Client/ConnectionEstablisher.h:79: DB::HedgedConnectionsFactory::getManyConnections(DB::PoolMode, std::function) @ 0x000000003ab4ec00 15. ./build_docker/./src/Client/HedgedConnections.cpp:64: DB::HedgedConnections::HedgedConnections(std::shared_ptr const&, std::shared_ptr, DB::ConnectionTimeouts const&, std::shared_ptr const&, DB::PoolMode, std::shared_ptr, std::function, std::function) @ 0x000000003ab2c32a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function, std::function&>(std::shared_ptr const&, std::shared_ptr&, DB::ConnectionTimeouts&, std::shared_ptr const&, DB::PoolMode&, std::shared_ptr&, std::function&&, std::function&) @ 0x000000002f2afe36 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:233: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107] const&, String const&, DB::Block const&, std::shared_ptr, std::shared_ptr const&, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::function)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f2923e7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 19. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.210918 [ 17376 ] {7e1f71c5-6bad-4e85-a37d-8cc9d53d894e} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34052) (comment: 03167_base64_url_functions.sql) (query 2, line 6) (in query: SELECT base64URLDecode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.219932 [ 17376 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.258029 [ 17376 ] {d176c894-3afb-426c-8b7d-95424b44d23d} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34052) (comment: 03167_base64_url_functions.sql) (query 3, line 7) (in query: SELECT tryBase64URLDecode();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.265436 [ 17376 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.318249 [ 17376 ] {e03d83bb-4dc8-49f5-b0a0-c290d8b25b43} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34052) (comment: 03167_base64_url_functions.sql) (query 4, line 8) (in query: SELECT base64URLEncode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.326432 [ 17376 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.371544 [ 17376 ] {82433856-63cb-4120-b0f2-99b1cb521e30} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34052) (comment: 03167_base64_url_functions.sql) (query 5, line 9) (in query: SELECT base64URLDecode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.380032 [ 17376 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.508128 [ 17376 ] {ad078a83-74fd-4242-974f-195c40992cdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34052) (comment: 03167_base64_url_functions.sql) (query 6, line 10) (in query: SELECT tryBase64URLDecode('foo', 'excess argument');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.516991 [ 17376 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode('foo', 'excess argument'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000289ea3d7 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000002c151a62 5. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153c17 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.770003 [ 18403 ] {77920bf6-ad6c-4bcf-acd7-6783d50474e9} executeQuery: Code: 60. DB::Exception: Table test_1.kill_mutation does not exist. Maybe you meant test_rr6dqsl7.kill_mutation_r1?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34082) (comment: 00834_kill_mutation.sh) (query 1, line 1) (in query: DROP TABLE kill_mutation), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:26:37.787106 [ 18403 ] {} TCPHandler: Code: 60. DB::Exception: Table test_1.kill_mutation does not exist. Maybe you meant test_rr6dqsl7.kill_mutation_r1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:26:38.003057 [ 18149 ] {51b236b3-2416-4271-a603-610688c34346} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'decrypt'. Expected: decryption mode string, got: UInt16: In scope SELECT decrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 8, line 26) (in query: SELECT decrypt(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:38.011446 [ 18149 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'decrypt'. Expected: decryption mode string, got: UInt16: In scope SELECT decrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:38.129429 [ 19620 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:38.565666 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 425.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:38.568141 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 425.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:38.784613 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 405.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:38.785770 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 405.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:38.972281 [ 18403 ] {2c0dcd0e-e982-47fa-9ea1-7b59a29c0b4f} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34110) (comment: 02294_dictionaries_hierarchical_index.sql) (query 3, line 8) (in query: INSERT INTO test_hierarchy_source_table VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:26:38.995245 [ 18403 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:26:39.002160 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:39.003403 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:39.448258 [ 18149 ] {2fde444c-8399-45ae-8614-9be4270fe8cf} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT decrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 9, line 27) (in query: SELECT decrypt('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d3985e2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:39.466727 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT decrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d3985e2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:39.645778 [ 18149 ] {e1adef78-ac11-4bdf-85fb-d4c131e2b87a} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT decrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 10, line 28) (in query: SELECT decrypt('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d3985e2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:39.657113 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT decrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d3985e2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:26:39.710575 [ 18149 ] {ebf0ff2a-79d6-49d7-a5e5-39d56c30a96f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'aes_decrypt_mysql'. Expected: decryption key binary string, got: UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 11, line 31) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:39.721282 [ 18149 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'aes_decrypt_mysql'. Expected: decryption key binary string, got: UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:39.966503 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1447 entries up to offset 477892: Code: 241. DB::Exception: (total) memory limit exceeded: would use 404.97 MiB (attempt to allocate chunk of 4.50 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:40.062741 [ 18721 ] {9a05f826-7dcf-4353-9e2c-8771f1fa9539} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56608) (comment: 00318_pk_tuple_order.sql) (query 10, line 15) (in query: SELECT `__table1`.`d` AS `d`, `__table1`.`x` AS `x`, `__table1`.`y` AS `y`, `__table1`.`z` AS `z` FROM `test_13`.`pk` AS `__table1` WHERE `__table1`.`x` = 1 ORDER BY `__table1`.`d` ASC, `__table1`.`x` ASC, `__table1`.`y` ASC, `__table1`.`z` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:26:40.084708 [ 18721 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:26:40.112589 [ 16355 ] {064742c0-53fd-4002-b0f7-0bc18a79e8d9} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 401.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34066) (comment: 00318_pk_tuple_order.sql) (query 10, line 15) (in query: SELECT * FROM pk WHERE x = 1 ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:26:40.118559 [ 4017 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43006, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:40.119494 [ 4017 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:43006, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:40.137638 [ 16355 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 401.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:40.161219 [ 4936 ] {366ad733-f56e-4b60-b859-d3c04409593f} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:44718). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44718) (comment: 00318_pk_tuple_order.sql) (query 10, line 15) (in query: SELECT `__table1`.`d` AS `d`, `__table1`.`x` AS `x`, `__table1`.`y` AS `y`, `__table1`.`z` AS `z` FROM `test_13`.`pk` AS `__table1` WHERE `__table1`.`x` = 1 ORDER BY `__table1`.`d` ASC, `__table1`.`x` ASC, `__table1`.`y` ASC, `__table1`.`z` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x000000003aea4d5d 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:26:40.173681 [ 4936 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:44718). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x000000003aea4d5d 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:26:40.373466 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:40.375014 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:40.385761 [ 5803 ] {34cea5ce-da11-44f4-8608-be31703fc2ab} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.31 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34146) (comment: 01325_freeze_mutation_stuck.sql) (query 3, line 3) (in query: INSERT INTO mt VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:26:40.391953 [ 17376 ] {f0850ac8-b861-4223-a79c-2cc5fa2122e0} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input 'https://clickhouse.com': In scope SELECT base64URLDecode('https://clickhouse.com'). (INCORRECT_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34052) (comment: 03167_base64_url_functions.sql) (query 13, line 25) (in query: -- test with invalid inputs SELECT base64URLDecode('https://clickhouse.com');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b25bc6d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b264e0f 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b264662 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b26355e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:40.397301 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:40.398305 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:40.401704 [ 17376 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input 'https://clickhouse.com': In scope SELECT base64URLDecode('https://clickhouse.com'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b25bc6d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b264e0f 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b264662 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b26355e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:40.405270 [ 5803 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.31 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:26:40.447065 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 449.97 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:40.449284 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 449.97 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:40.596910 [ 17376 ] {786cccd8-b0b5-4cd4-844e-0cde9b833c99} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input '12?': In scope SELECT base64URLDecode('12?'). (INCORRECT_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34052) (comment: 03167_base64_url_functions.sql) (query 15, line 29) (in query: SELECT base64URLDecode('12?');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b25bc6d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b264e0f 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b264662 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b26355e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:40.605493 [ 17376 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input '12?': In scope SELECT base64URLDecode('12?'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b25bc6d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b264e0f 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b264662 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b26355e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:40.735067 [ 17376 ] {ef09e992-c999-41b8-9829-4a06c127a739} executeQuery: Code: 117. DB::Exception: Failed to base64URLDecode input 'aHR0cHM6Ly9jbGlja': In scope SELECT base64URLDecode('aHR0cHM6Ly9jbGlja'). (INCORRECT_DATA) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34052) (comment: 03167_base64_url_functions.sql) (query 17, line 31) (in query: SELECT base64URLDecode('aHR0cHM6Ly9jbGlja');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b25bc6d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b264e0f 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b264662 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b26355e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:40.743473 [ 17376 ] {} TCPHandler: Code: 117. DB::Exception: Failed to base64URLDecode input 'aHR0cHM6Ly9jbGlja': In scope SELECT base64URLDecode('aHR0cHM6Ly9jbGlja'). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const* const&, String&&) @ 0x000000000b25bc6d 4. DB::Base64Decode<(DB::Base64Variant)1>::perform(std::basic_string_view>, char8_t*) @ 0x000000000b264e0f 5. DB::FunctionBase64Conversion>::execute(DB::ColumnString const&, unsigned long) @ 0x000000000b264662 6. DB::FunctionBase64Conversion>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b26355e 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 8. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 29. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 30. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:26:41.089765 [ 18149 ] {3453d78d-22fa-4227-b28a-dde880c718ac} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 12, line 33) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000b203039 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b20090d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:41.099793 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000b203039 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b20090d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:41.548478 [ 10170 ] {868f69c6-e175-46a9-a14d-b0528981c703} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function less: In scope SELECT today() < ((2018 - 11) - 14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34160) (comment: 00762_date_comparsion.sql) (query 2, line 3) (in query: select today() < 2018-11-14;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001339edbe 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:41.557531 [ 10170 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function less: In scope SELECT today() < ((2018 - 11) - 14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001339edbe 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:41.827651 [ 16761 ] {} ExternalDictionariesLoader: Could not update external dictionary '2e0ae505-ea41-462e-9e29-c6d219b9ba0d', leaving the previous version, next update is scheduled at 2025-11-13 09:26:46: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=46, jobs=0): While reading or decompressing /var/lib/clickhouse/store/4e3/4e354e04-9bcb-45df-863e-d62651260a57/all_1_1_0/data.bin (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading column key): (while reading from part /var/lib/clickhouse/store/4e3/4e354e04-9bcb-45df-863e-d62651260a57/all_1_1_0/ in table test_t8ygedj6.dicttbl (4e354e04-9bcb-45df-863e-d62651260a57) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000002d1e7a41 7. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:ne190107] (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority), std::future (std::function&&, Priority)>>(std::__function::__policy_storage const*, std::function&&, Priority&&) @ 0x000000002d1e7460 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002d1e3cf1 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000002d1c2f4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000002d1c4084 11. DB::ReadBuffer::next() @ 0x0000000008ef7cef 12. ./src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x000000003dd2c353 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd38316 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6f8227 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x0000000039f17708 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x000000003c358f91 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:217: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fe55 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:41.903234 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.26 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:41.905257 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.26 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:42.464723 [ 18149 ] {f92bcc4f-5d7d-4d13-b55e-252f7392bbae} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 13, line 35) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:42.475713 [ 18149 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:42.536825 [ 18149 ] {4da89e17-bfb9-4734-8298-0f86875d06c5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'decrypt'. Expected: decryption key binary string, got: UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 14, line 36) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:42.545924 [ 18149 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'decrypt'. Expected: decryption key binary string, got: UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a0ff 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:42.706199 [ 17227 ] {00cb7530-1c47-43d7-abce-b4858a7e8f11} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.90 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38558) (comment: 00931_low_cardinality_nullable_aggregate_function_type.sql) (query 4, line 5) (in query: SELECT date, argMax(name, clicks) FROM lc GROUP BY date;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:26:42.708863 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.99 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:42.710961 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.99 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:42.761602 [ 17227 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.90 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:43.045164 [ 10170 ] {bb989d4a-0560-4469-9917-4ebf8e3ef12c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function less: In scope SELECT toDate('2018-01-01') < 1. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34160) (comment: 00762_date_comparsion.sql) (query 10, line 13) (in query: select toDate('2018-01-01') < 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001339edbe 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:43.053126 [ 10170 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function less: In scope SELECT toDate('2018-01-01') < 1. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001339edbe 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:43.402958 [ 3727 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_99_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.76 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:43.405361 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_99_15}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.76 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:43.596875 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:43.597883 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:43.709046 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:43.710304 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:43.866033 [ 18149 ] {89894a0b-df96-4bfd-8a49-2c58517bc077} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 15, line 37) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39c893 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d397dec 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:43.872854 [ 16047 ] {1c2da635-6747-4e2a-bd3d-2fa97b33dc4d} executeQuery: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:44944): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44944) (comment: 00931_low_cardinality_nullable_aggregate_function_type.sql) (query 4, line 5) (in query: SELECT `__table1`.`date` AS `date`, argMax(`__table1`.`name`, `__table1`.`clicks`) AS `argMax(name, clicks)` FROM `test_13`.`lc` AS `__table1` GROUP BY `__table1`.`date`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1412: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl[abi:ne190107] (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000003af12259 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039f461f8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039f39892 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:154: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3d704f 10. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c2eb3f4 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:26:43.876615 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39c893 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d397dec 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:43.948459 [ 18149 ] {1d5adfdf-1cbc-4760-8a11-0f52a37baa25} executeQuery: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 16, line 38) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39c893 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d397dec 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:43.982043 [ 16047 ] {} TCPHandler: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:44944): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1412: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl[abi:ne190107] (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000003af12259 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039f461f8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039f39892 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:154: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c3d704f 10. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003c2eb3f4 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:201: DB::MergeTreeSelectProcessor::read() @ 0x0000000039f3fc16 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x000000003c306107 13. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:43.992183 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.41 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:43.994440 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.41 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.038539 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39c893 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d397dec 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:44.049875 [ 3724 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_167_41} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.21 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.052022 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_167_41}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.21 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.146063 [ 3736 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_92_96_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_96_96_0/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 15): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.147860 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_92_96_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_96_96_0/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 15): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.214588 [ 3739 ] {9567f5dc-109b-4dc6-afc3-efbae913fd59::all_1_16_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.217145 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {9567f5dc-109b-4dc6-afc3-efbae913fd59::all_1_16_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.278229 [ 10170 ] {51fdc1ca-6b20-4c20-ae24-0492e22f3830} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope SELECT toDate('2018-01-01') = 1. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34160) (comment: 00762_date_comparsion.sql) (query 11, line 14) (in query: select toDate('2018-01-01') == 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000df8d817 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:44.287809 [ 10170 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope SELECT toDate('2018-01-01') = 1. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000df8d817 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:44.305129 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.306109 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.318153 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.319222 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.440447 [ 16355 ] {5b80f06d-84eb-4a56-8200-864ca0e9be09} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.71 MiB (attempt to allocate chunk of 1.96 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38598) (comment: 00634_performance_introspection_and_logging.sh) (query 1, line 1) (in query: INSERT INTO null_00634 FORMAT RowBinary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 2025.11.13 09:26:44.469747 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.470852 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.487982 [ 16355 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.71 MiB (attempt to allocate chunk of 1.96 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 23. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 2025.11.13 09:26:44.567142 [ 18403 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 370.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.637340 [ 3736 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_167_41} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 376.62 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.639397 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_167_41}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 376.62 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.945380 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.45 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:44.947560 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.45 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:45.169251 [ 16693 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:45.169278 [ 19619 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:45.170367 [ 16693 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:45.171387 [ 19619 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.79 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:45.463414 [ 19620 ] {5ce49b61-4c07-4575-bc76-ad5983523bd1} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.84 MiB (attempt to allocate chunk of 7.63 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38652) (comment: 02499_monotonicity_toUnixTimestamp64.sh) (query 1, line 1) (in query: create table t(ts DateTime64) engine=MergeTree order by ts as select * from numbers_mt(1e6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037b1704e 12. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x000000003c45cba0 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:26:45.481818 [ 15982 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:45.483040 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:45.489628 [ 19620 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.84 MiB (attempt to allocate chunk of 7.63 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing NumbersRange. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037b1704e 12. ./src/Common/COW.h:293: DB::(anonymous namespace)::NumbersRangedSource::generate() @ 0x000000003c45cba0 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 19. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:26:45.654518 [ 18149 ] {2fdc83d3-5014-4383-85e7-bbbba200b98d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'aes_decrypt_mysql'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 17, line 40) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:45.662156 [ 18149 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'aes_decrypt_mysql'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:45.805581 [ 10170 ] {a6419891-de62-405a-9885-8fb8474b1dee} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function notEquals: In scope SELECT toDate('2018-01-01') != 1. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34160) (comment: 00762_date_comparsion.sql) (query 12, line 15) (in query: select toDate('2018-01-01') != 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000174a8037 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:45.814211 [ 10170 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function notEquals: In scope SELECT toDate('2018-01-01') != 1. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000174a8037 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:46.464773 [ 16198 ] {aad3ecc0-3805-4ad2-af96-de4f4e9a8fa2} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.12 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38684) (comment: 02286_parallel_final.sh) (query 3, line 4) (in query: insert into tbl_8parts_3granules_rnd select number, 1 from numbers_mt(196608);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037b0e38e 12. DB::IColumn::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x000000002c15723f 13. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec073 14. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 15. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:26:46.500692 [ 16198 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.12 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037b0e38e 12. DB::IColumn::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x000000002c15723f 13. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec073 14. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 15. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:26:46.540519 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.87 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:46.542450 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.87 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:46.620495 [ 19619 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 370.98 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:46.621551 [ 19619 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 370.98 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:46.672138 [ 19619 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:46.673303 [ 19619 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:46.738020 [ 3935 ] {be366c3b-b16e-4789-9fb2-8814c1e96799} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000003 */ ALTER TABLE test_1.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000031a82458 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x0000000031a6daad 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x0000000031ac4446 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031ac41ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:26:46.743706 [ 3935 ] {be366c3b-b16e-4789-9fb2-8814c1e96799} DDLWorker: Query /* ddl_entry=query-0000000003 */ ALTER TABLE test_1.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000031a82458 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x0000000031a6daad 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x0000000031ac4446 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031ac41ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:47.270258 [ 16693 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:47.271374 [ 16693 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:47.368977 [ 18149 ] {b16549bb-bb39-4be4-bbbd-815c852309cf} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 18, line 42) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000b203039 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b200c12 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:47.378597 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000b203039 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b200c12 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:47.626926 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:47.690976 [ 16132 ] {2a6a6e0d-7d55-4ca8-96bf-f8808095c3a1} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38736) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_1.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:47.710613 [ 16132 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:47.943399 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.52 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:47.945951 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.52 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:48.320513 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:48.321664 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:48.436049 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 374.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:48.437294 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 374.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:48.521403 [ 18149 ] {17e79875-1769-4bec-b7f5-d18657aa93c1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'decrypt'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 19, line 44) (in query: SELECT decrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:48.530000 [ 18149 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'decrypt'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:48.702575 [ 5803 ] {a8598409-4af1-4a7e-8bdc-2f44594697b6} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.37 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while pushing to view test_13.t_mv_00751 (05f2dc37-5d61-4ea2-b08a-63ec705ba141). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38622) (comment: 00751_default_databasename_for_view.sql) (query 18, line 35) (in query: INSERT INTO test_13.t_00751 FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf87b 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 17. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 22. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 30. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 31. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 2025.11.13 09:26:48.753719 [ 5803 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.37 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while pushing to view test_13.t_mv_00751 (05f2dc37-5d61-4ea2-b08a-63ec705ba141). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf87b 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 17. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 22. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 30. ./build_docker/./src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x000000003aed23b9 31. ./build_docker/./src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x000000003aea4b98 2025.11.13 09:26:48.815332 [ 16198 ] {3c94b6d6-0df0-4f59-a5e1-ffb54cc2c764} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 374.34 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38804) (comment: 03393_join_bug_77848.sql) (query 4, line 6) (in query: INSERT INTO BadTable SELECT toUInt128(12);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:26:48.839219 [ 16198 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 374.34 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:26:49.195645 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.201694 [ 16198 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.202869 [ 16198 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.261686 [ 3725 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_99_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.90 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.264137 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_99_15}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.90 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.471316 [ 3732 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.42 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.473718 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.42 MiB (attempt to allocate chunk of 1.23 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.483444 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.484554 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.656209 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.27 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.657477 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.27 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.822951 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 377.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.824050 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 377.31 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.835332 [ 18149 ] {768dc0a4-a371-4b3d-8f30-f2e9d09adb77} executeQuery: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 20, line 45) (in query: SELECT decrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b2043ed 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39ccc2 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d3980af 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:49.843949 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b2043ed 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39ccc2 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d3980af 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:49.896602 [ 18149 ] {100f336b-971f-49c4-be44-3e3bd6a5af89} executeQuery: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 21, line 46) (in query: SELECT decrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b2043ed 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39ccc2 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d3980af 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:49.903991 [ 18149 ] {} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT decrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000b2043ed 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39ccc2 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d3980af 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:26:49.912296 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 377.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:49.913592 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 377.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.049110 [ 18149 ] {87cd6358-0f10-416a-bd49-bd425941ce71} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 22, line 48) (in query: SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:50.058918 [ 18149 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT aes_decrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x000000002c191997 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18ae90 5. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b201c5e 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:26:50.115876 [ 18149 ] {84dccf49-e012-48b9-af9c-4cb365da7d21} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'decrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 23, line 51) (in query: SELECT decrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:50.123780 [ 18149 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'decrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT decrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:50.179908 [ 18149 ] {0c197c85-28da-48fe-be2f-30339b04aac9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'decrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 24, line 52) (in query: SELECT decrypt('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:50.188190 [ 18149 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'decrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT decrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000002c192407 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000002c18b841 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000002c18a16f 6. DB::FunctionDecrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000d399b01 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:26:50.209119 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.210518 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.492024 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.501181 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.584651 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.585847 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.626534 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.627802 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.629943 [ 2997 ] {002b01fe-a5e2-41e3-8393-826820613490} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.99 MiB (attempt to allocate chunk of 1.63 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38906) (comment: 03222_datetime64_small_value_const.sql) (query 3, line 5) (in query: select *, (select toDateTime64(0, 3)) from remote('127.0.0.1', system.one) settings prefer_localhost_replica=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 18. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:26:50.658700 [ 2997 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.99 MiB (attempt to allocate chunk of 1.63 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 18. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:50.666105 [ 16887 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.667406 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.690417 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 17 entries up to offset 2297: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.50 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:50.920090 [ 16693 ] {d6b9d4e7-03d4-4bbf-83e8-d02313d2bd19} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 376.72 MiB (attempt to allocate chunk of 1.19 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: while converting source column number to destination column key1: while executing 'FUNCTION _CAST(number :: 0, UInt32 :: 2) -> _CAST(number, UInt32) UInt32 : 4'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38820) (comment: 02286_parallel_final.sh) (query 3, line 4) (in query: insert into tbl_8parts_8granules_rnd select number, 1 from numbers_mt(524288);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c115fc 12. ./src/Functions/FunctionsConversion.h:1674: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca1a0cc 13. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca12739 14. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e20d 15. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 16. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 21. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 22. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 23. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 27. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 28. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 29. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 30. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 2025.11.13 09:26:50.966663 [ 16693 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 376.72 MiB (attempt to allocate chunk of 1.19 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: while converting source column number to destination column key1: while executing 'FUNCTION _CAST(number :: 0, UInt32 :: 2) -> _CAST(number, UInt32) UInt32 : 4'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c115fc 12. ./src/Functions/FunctionsConversion.h:1674: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca1a0cc 13. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca12739 14. ./src/Core/callOnTypeIndex.h:255: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93e20d 15. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95aebd 16. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt32, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c959e02 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 21. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 22. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 23. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 27. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 28. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 29. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 30. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 31. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:26:51.397924 [ 17752 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.50 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:51.399484 [ 17752 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.50 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:51.415063 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.50 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:51.418429 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.50 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:51.425879 [ 17752 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:51.427146 [ 17752 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:51.445232 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 2264 entries up to offset 310322: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.03 MiB (attempt to allocate chunk of 4.18 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:51.450018 [ 17752 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:51.451218 [ 17752 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:51.575050 [ 18149 ] {c6c63c4e-401d-41ff-bb4f-74a5d23b25d6} executeQuery: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 478150763: In scope SELECT ignore(decrypt('aes-128-ecb', '[HIDDEN]')). (OPENSSL_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 25, line 54) (in query: SELECT ignore(decrypt('aes-128-ecb', '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::OpenSSLDetails::onError(String) @ 0x0000000008c9b0ec 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39cd1b 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d397dec 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:26:51.671081 [ 18149 ] {} TCPHandler: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 478150763: In scope SELECT ignore(decrypt('aes-128-ecb', '[HIDDEN]')). (OPENSSL_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::OpenSSLDetails::onError(String) @ 0x0000000008c9b0ec 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39cd1b 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d397dec 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:26:51.819324 [ 18149 ] {0a25a21e-b1f2-4921-922f-d8d42216e336} executeQuery: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 478150763: In scope SELECT ignore(decrypt('aes-128-cbc', '[HIDDEN]')). (OPENSSL_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 26, line 56) (in query: SELECT ignore(decrypt('aes-128-cbc', '[HIDDEN]'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::OpenSSLDetails::onError(String) @ 0x0000000008c9b0ec 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39cd1b 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d397dec 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:26:51.830175 [ 18149 ] {} TCPHandler: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 478150763: In scope SELECT ignore(decrypt('aes-128-cbc', '[HIDDEN]')). (OPENSSL_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::OpenSSLDetails::onError(String) @ 0x0000000008c9b0ec 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39cd1b 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d397dec 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2926: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030463cd2 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 31. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 2025.11.13 09:26:52.143487 [ 19620 ] {540162b3-61fd-446b-8c14-7fa02e577596} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 368.91 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.24 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:38758) (comment: 03036_dynamic_read_shared_subcolumns_small.gen.sql) (query 18, line 22) (in query: select count() from test where dynamicType(d) == 'String';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:26:52.219124 [ 17752 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 377.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:52.220708 [ 17752 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 377.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:52.264505 [ 19620 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 368.91 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.24 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:52.459108 [ 3935 ] {74dd28da-555c-4721-b464-81d7a24b7de9} executeQuery: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000004 */ ALTER TABLE test_1.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000031a82458 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x0000000031a6daad 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x0000000031ac4446 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031ac41ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:26:52.464278 [ 3935 ] {74dd28da-555c-4721-b464-81d7a24b7de9} DDLWorker: Query /* ddl_entry=query-0000000004 */ ALTER TABLE test_1.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000031a82458 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x0000000031a6daad 12. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x0000000031ac4446 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031ac41ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:52.713821 [ 18392 ] {c97bd56a-aac6-4fb8-b31a-7a918421c21b} executeQuery: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)). (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50980) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_1.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:52.733066 [ 18392 ] {} TCPHandler: Code: 60. DB::Exception: There was an error on [localhost:9000]: Code: 60. DB::Exception: Could not find table: t1. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:52.980310 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:52.982860 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_115_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:52.988629 [ 2997 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 376.56 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:52.989779 [ 2997 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 376.56 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:53.159631 [ 18728 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:53.161535 [ 18728 ] {} DynamicQueryHandler: Cannot send exception to client: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./build_docker/./src/Server/HTTPHandler.cpp:623: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace72e6 14. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:53.208453 [ 3737 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.72 MiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:53.210448 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.72 MiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:53.930831 [ 3729 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.73 MiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:53.935783 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.73 MiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.154585 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.155570 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.187921 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1137 entries up to offset 481280: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.60 MiB (attempt to allocate chunk of 4.40 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.454386 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.14 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.456847 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.14 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.531592 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.533108 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.652711 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.653825 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.901449 [ 3738 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_92_96_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_93_93_0/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 17): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.903683 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_92_96_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_93_93_0/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 17): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.932535 [ 3731 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.61 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.934589 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.61 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.954696 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.61 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.955795 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.61 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.994161 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.61 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:54.995449 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.61 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:55.503430 [ 16887 ] {e1aac8f0-82f5-4499-9973-1a213ffd7075} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.95 MiB (attempt to allocate chunk of 2.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION CAST(divide(key1, 24576) :: 3, 'UInt64' :: 2) -> CAST(divide(key1, 24576), 'UInt64') UInt64 : 1'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50968) (comment: 02286_parallel_final.sh) (query 3, line 4) (in query: insert into tbl_8parts_3granules_seq select number, 1 from numbers_mt(196608);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./src/Functions/FunctionsConversion.h:1674: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca49d7c 13. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3a219 14. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93ec63 15. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 16. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 21. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 22. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 23. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 27. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 29. ./build_docker/./src/Storages/MergeTree/MergeTreePartition.cpp:484: DB::MergeTreePartition::executePartitionByExpression(std::shared_ptr const&, DB::Block&, std::shared_ptr) @ 0x0000000039e426bd 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:334: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c762db 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 2025.11.13 09:26:55.533112 [ 16887 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.95 MiB (attempt to allocate chunk of 2.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION CAST(divide(key1, 24576) :: 3, 'UInt64' :: 2) -> CAST(divide(key1, 24576), 'UInt64') UInt64 : 1'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./src/Functions/FunctionsConversion.h:1674: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ca49d7c 13. ./src/Functions/FunctionsConversion.h:2467: bool DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeNumber>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002ca3a219 14. ./src/Core/callOnTypeIndex.h:268: bool DB::callOnIndexAndDataType, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString>(DB::TypeIndex, DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x000000002c93ec63 15. ./src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95e6bd 16. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert, DB::detail::NameToUInt64, DB::detail::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c95d602 17. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 21. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 22. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 23. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 24. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 25. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 26. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 27. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:816: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x0000000031b7132a 29. ./build_docker/./src/Storages/MergeTree/MergeTreePartition.cpp:484: DB::MergeTreePartition::executePartitionByExpression(std::shared_ptr const&, DB::Block&, std::shared_ptr) @ 0x0000000039e426bd 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:334: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c762db 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:26:55.671630 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.56 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:55.672782 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.56 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:55.698643 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:55.699973 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:56.347079 [ 16233 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:56.347539 [ 17383 ] {58184141-c71f-4f89-a7bf-107b791b58db} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=870). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51034) (comment: 00701_rollup.sql) (query 9, line 16) (in query: SELECT a, sum(s), count() from rollup GROUP BY a WITH ROLLUP ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:26:56.348125 [ 16233 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:56.354787 [ 18106 ] {0c49eaaa-1210-4f8c-bc4b-26a4eb45dd5c} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.91 MiB (attempt to allocate chunk of 1.09 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51130) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: INSERT INTO tMM SELECT toDateTime('2020-09-01 00:00:00', 'Asia/Istanbul') + number*60, number FROM numbers(5000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:26:56.370147 [ 17383 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1185, jobs=870). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001fac80d4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab51c4 5. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 6. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 8. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 9. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:26:56.425892 [ 18106 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.91 MiB (attempt to allocate chunk of 1.09 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:26:56.640011 [ 3739 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.52 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:56.646503 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.52 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:56.758389 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 392.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:56.759498 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 392.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.003610 [ 3728 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.92 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.006035 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.92 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.012623 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.013708 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.041262 [ 3935 ] {3c280148-88eb-487c-9412-0a3dbc33349c} executeQuery: Code: 15. DB::Exception: Cannot add column `newcol`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000006 */ ALTER TABLE test_1.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1444: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a31ea 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x0000000031a9ae1b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8a9af 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000031a82458 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x0000000031a6daad 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x0000000031ac4446 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031ac41ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:57.048043 [ 3935 ] {3c280148-88eb-487c-9412-0a3dbc33349c} DDLWorker: Query /* ddl_entry=query-0000000006 */ ALTER TABLE test_1.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 15. DB::Exception: Cannot add column `newcol`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1444: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a31ea 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x0000000031a9ae1b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8a9af 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000031a82458 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x0000000031a6daad 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x0000000031ac4446 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031ac41ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.054202 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.055330 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.121200 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.122742 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.132904 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.133927 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.346931 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.348597 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.393014 [ 16344 ] {69f84b59-49df-4b7a-b03d-1ec2945df967} executeQuery: Code: 15. DB::Exception: There was an error on [localhost:9000]: Code: 15. DB::Exception: Cannot add column `newcol`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)). (DUPLICATE_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51118) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_1.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:57.512067 [ 16344 ] {} TCPHandler: Code: 15. DB::Exception: There was an error on [localhost:9000]: Code: 15. DB::Exception: Cannot add column `newcol`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)). (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:57.516526 [ 3733 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_99_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_1_88_14/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 1526): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.518496 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_99_15}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_1_88_14/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 1526): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.782186 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.783378 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.824442 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.825538 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.853472 [ 3916 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TraceLogElement]: Failed to flush system log system.trace_log with 3526 entries up to offset 100530: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.71 MiB (attempt to allocate chunk of 4.77 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 11. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 12. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 14. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 15. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 16. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 17. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 20. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 22. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 24. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 31. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:57.922660 [ 18392 ] {6b5c415d-a64c-4c7f-b673-3e0ae746c7b9} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.66 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51126) (comment: 03215_parsing_archive_name_s3.sql) (query 2, line 6) (in query: INSERT INTO FUNCTION s3(s3_conn, filename='::03215_archive.csv') SELECT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b7113db 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b716083 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:26:58.046259 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.63 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.048268 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.63 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.054092 [ 3738 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.20 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.056799 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.20 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.181442 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.182749 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.252931 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.254153 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.322832 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.324135 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.453245 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.454409 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.462883 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.463936 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.500994 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 18 entries up to offset 2315: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.37 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.724429 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 1981 entries up to offset 312303: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.40 MiB (attempt to allocate chunk of 4.16 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.763358 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.24 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.764506 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.24 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:58.801072 [ 2997 ] {d5ca6d87-00fa-431c-987c-695b37063b36} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55148) (comment: 02294_stringsearch_with_nonconst_needle.sql) (query 9, line 24) (in query: SELECT `__table1`.`id` AS `id`, `__table1`.`haystack` AS `haystack`, `__table1`.`needle` AS `needle`, `__table1`.`haystack` ILIKE `__table1`.`needle` AS `ilike(haystack, needle)` FROM `test_9`.`non_const_needle` AS `__table1` ORDER BY `__table1`.`id` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:26:58.801363 [ 17268 ] {3178ee95-7e87-4672-a8e9-0b0b6da0709e} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33952) (comment: 02294_stringsearch_with_nonconst_needle.sql) (query 9, line 24) (in query: SELECT `__table1`.`id` AS `id`, `__table1`.`haystack` AS `haystack`, `__table1`.`needle` AS `needle`, `__table1`.`haystack` ILIKE `__table1`.`needle` AS `ilike(haystack, needle)` FROM `test_9`.`non_const_needle` AS `__table1` ORDER BY `__table1`.`id` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:26:58.803919 [ 18392 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.66 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::ParallelFormattingOutputFormat::formatterThreadFunction(unsigned long, unsigned long, std::shared_ptr const&) @ 0x000000003b7113db 12. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:298: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b716083 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x000000003b713277 5. ./build_docker/./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000003b7101f8 6. ./src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:136: DB::ParallelFormattingOutputFormat::writeSuffix() @ 0x000000003b715767 7. ./src/Processors/Formats/IOutputFormat.h:125: DB::IOutputFormat::finalize() @ 0x000000003b228cc8 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:72: DB::StorageObjectStorageSink::finalizeBuffers() @ 0x000000002d575f71 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:60: DB::StorageObjectStorageSink::onFinish() @ 0x000000002d575c60 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0ec2f 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d7fc 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:26:58.815187 [ 2997 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:26:58.815454 [ 16215 ] {74673d86-362e-4e34-a95c-3ee0bda92346} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 387.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51066) (comment: 02294_stringsearch_with_nonconst_needle.sql) (query 9, line 24) (in query: select id, haystack, needle, ilike(haystack, needle) from non_const_needle order by id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:26:58.817426 [ 17268 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:26:58.839458 [ 16215 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 387.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:26:59.178100 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 365.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.178258 [ 16203 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 365.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.179345 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 365.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.180452 [ 16203 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 365.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.206549 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1036 entries up to offset 482316: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.36 MiB (attempt to allocate chunk of 4.43 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 10. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 11. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 12. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 13. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 27. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 28. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x000000003335e7be 29. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba3381 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba31bf 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.512897 [ 3728 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.09 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column LatencyEvent_S3FirstByteReadAttempt2Microseconds): (while reading from part /var/lib/clickhouse/store/1ec/1ec8b98a-4739-4044-a897-d4d41f41f429/202511_1_161_32/ in table system.latency_log (1ec8b98a-4739-4044-a897-d4d41f41f429) located on disk default of type local, from mark 0 with max_rows_to_read = 1190): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.514654 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_166_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.09 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column LatencyEvent_S3FirstByteReadAttempt2Microseconds): (while reading from part /var/lib/clickhouse/store/1ec/1ec8b98a-4739-4044-a897-d4d41f41f429/202511_1_161_32/ in table system.latency_log (1ec8b98a-4739-4044-a897-d4d41f41f429) located on disk default of type local, from mark 0 with max_rows_to_read = 1190): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.535934 [ 16203 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 367.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.536974 [ 16203 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 367.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.753940 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 376.96 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.755804 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 376.96 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:26:59.956659 [ 19606 ] {4280abd1-6469-4e48-939e-82235403d9ae} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.23 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51138) (comment: 02286_parallel_final.sh) (query 3, line 4) (in query: insert into tbl_8parts_5granules_seq select number, 1 from numbers_mt(327680);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037b0e38e 12. ./build_docker/./src/Columns/IColumn.cpp:254: DB::IColumnHelper, DB::ColumnFixedSizeHelper>::scatter(unsigned long, DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003818ebd8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:369: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7bce0 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:27:00.049695 [ 19606 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.23 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037b0e38e 12. ./build_docker/./src/Columns/IColumn.cpp:254: DB::IColumnHelper, DB::ColumnFixedSizeHelper>::scatter(unsigned long, DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003818ebd8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:369: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7bce0 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:27:00.049769 [ 18106 ] {a1046143-c127-4341-9d49-26a5a37e12d2} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51144) (comment: 02676_optimize_old_parts_replicated.sh) (query 6, line 9) (in query: INSERT INTO test_without_merge SELECT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:373: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a3c209c 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:27:00.077237 [ 18106 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:373: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a3c209c 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:27:00.269097 [ 3935 ] {69a21fd2-bbac-4d31-b3d8-994508184000} executeQuery: Code: 15. DB::Exception: Cannot add column `newcol`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01671_ddl_hang_timeout_long.sh) (in query: /* ddl_entry=query-0000000007 */ ALTER TABLE test_1.t1 (ADD COLUMN `newcol` UInt32)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1444: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a31ea 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x0000000031a9ae1b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8a9af 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000031a82458 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x0000000031a6daad 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x0000000031ac4446 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031ac41ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:27:00.270052 [ 3935 ] {69a21fd2-bbac-4d31-b3d8-994508184000} DDLWorker: Query /* ddl_entry=query-0000000007 */ ALTER TABLE test_1.t1 (ADD COLUMN `newcol` UInt32) wasn't finished successfully: Code: 15. DB::Exception: Cannot add column `newcol`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Storages/AlterCommands.cpp:1444: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000382a31ea 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329910a2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:871: DB::DDLWorker::tryExecuteQueryOnLeaderReplica(DB::DDLTaskBase&, std::shared_ptr, String const&, std::shared_ptr const&, std::unique_ptr>&) @ 0x0000000031a9ae1b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:670: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8a9af 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000031a82458 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x0000000031a6daad 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x0000000031ac4446 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x0000000031ac41ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:00.370182 [ 17228 ] {938cb709-0896-41ba-993a-9f65c2e2b190} executeQuery: Code: 15. DB::Exception: There was an error on [localhost:9000]: Code: 15. DB::Exception: Cannot add column `newcol`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)). (DUPLICATE_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51360) (comment: 01671_ddl_hang_timeout_long.sh) (query 1, line 1) (in query: ALTER TABLE test_1.t1 on cluster test_shard_localhost ADD COLUMN newcol UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:00.384693 [ 17228 ] {} TCPHandler: Code: 15. DB::Exception: There was an error on [localhost:9000]: Code: 15. DB::Exception: Cannot add column `newcol`: column with this name already exists. (DUPLICATE_COLUMN) (version 25.3.8.10072.altinitytest (altinity build)). (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000033801a51 4. ./build_docker/./src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x0000000031b4f92a 5. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 6. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 7. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 11. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:00.845298 [ 16203 ] {3e2ff600-5aaf-4067-8840-085672bb0dea} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.94 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57972) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_11`.`tMM` AS `__table1` WHERE toDate(`__table1`.`d`) = _CAST('2020-09-01', 'Date')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:27:00.865758 [ 16203 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.94 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:00.873488 [ 17385 ] {8f15da02-3a35-4d55-b352-ebeb3be1e818} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: (total) memory limit exceeded: would use 371.94 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51310) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toDate(d)=toDate('2020-09-01');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:00.906001 [ 17385 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: (total) memory limit exceeded: would use 371.94 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:00.934919 [ 3903 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryLogElement]: Failed to flush system log system.query_log with 411 entries up to offset 64820: Code: 241. DB::Exception: (total) memory limit exceeded: would use 368.93 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037b1704e 10. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037c876ba 11. ./src/Columns/ColumnsCommon.h:125: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037b2cbe9 12. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037b2c96e 13. ./build_docker/./src/Columns/ColumnTuple.cpp:463: DB::ColumnTuple::index(DB::IColumn const&, unsigned long) const @ 0x000000003777b384 14. ./build_docker/./src/Columns/ColumnArray.cpp:959: COW::immutable_ptr DB::ColumnArray::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000370bbadb 15. ./src/Columns/ColumnsCommon.h:136: DB::ColumnArray::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000370ab628 16. ./build_docker/./src/Columns/ColumnMap.cpp:230: DB::ColumnMap::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000375e6715 17. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:47: DB::permuteBlockIfNeeded(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039829bfb 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:189: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba572d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332cf2e1 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.219078 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 480.44 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.220400 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 480.44 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.234071 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.235241 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.245736 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.246969 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.382031 [ 3726 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 480.51 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.384430 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 480.51 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.958206 [ 3731 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_89_100_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.33 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.960988 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_89_100_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.33 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.979808 [ 3739 ] {bdf0480b-afe4-43b4-94a8-3b67feeb1240::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 241. DB::Exception: (total) memory limit exceeded: would use 368.32 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.982402 [ 3739 ] {bdf0480b-afe4-43b4-94a8-3b67feeb1240::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 241. DB::Exception: (total) memory limit exceeded: would use 368.32 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:230: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032eb6bd6 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000003a0a6ec1 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000003a0a4916 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.984288 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {bdf0480b-afe4-43b4-94a8-3b67feeb1240::all_1_1_0_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 368.32 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:230: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000032eb6bd6 7. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2243: DB::MutateTask::prepare() @ 0x000000003a0a6ec1 8. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2103: DB::MutateTask::execute() @ 0x000000003a0a4916 9. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:100: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a583640 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 15. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.985797 [ 16344 ] {17399ae9-92d8-4adf-8fd8-3e90779e2336} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_0' reason: 'Code: 241. DB::Exception: (total) memory limit exceeded: would use 368.32 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x00000000339eeec6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 . (UNFINISHED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51366) (comment: 02319_lightweight_delete_on_merge_tree_compact_parts.sql) (query 6, line 11) (in query: DELETE FROM merge_table_standard_delete WHERE id = 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x00000000339eeec6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:27:01.995779 [ 17390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:01.996926 [ 17390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:02.007004 [ 16344 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_0' reason: 'Code: 241. DB::Exception: (total) memory limit exceeded: would use 368.32 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18a3f 2. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 3. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x00000000339eeec6 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&, String&&) @ 0x0000000039e18d87 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039e18b00 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a4b22c1 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a4b5ae6 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:236: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000032991e53 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 9. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x00000000339eeec6 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:27:02.016341 [ 17390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:02.017410 [ 17390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:02.020007 [ 4170 ] {cba61bb0-1b1c-4554-be2f-bd499e1c6a22} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 471.37 MiB (attempt to allocate chunk of 4.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46106) (comment: 02286_parallel_final.sh) (query 3, line 4) (in query: insert into tbl_8parts_8granules_seq select number, 1 from numbers_mt(524288);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c78744 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:27:02.024875 [ 16203 ] {bac6b371-8001-41c1-aeae-a8a8065e74d6} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.64 MiB (attempt to allocate chunk of 1.32 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46170) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toDate(d)=toDate('2020-10-15');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003aa90dc2 18. ./build_docker/./src/Client/ConnectionPool.cpp:103: DB::ConnectionPool::get(DB::ConnectionTimeouts const&, DB::Settings const&, bool) @ 0x000000003aaf0e2c 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:51: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadb565 20. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:108: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107], String const&, DB::Block const&, std::shared_ptr, std::shared_ptr, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::shared_ptr)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f28b236 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 22. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 23. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 24. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 25. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:02.045658 [ 4170 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 471.37 MiB (attempt to allocate chunk of 4.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c78744 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 17. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 22. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:27:02.052977 [ 16203 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 369.64 MiB (attempt to allocate chunk of 1.32 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003aa90dc2 18. ./build_docker/./src/Client/ConnectionPool.cpp:103: DB::ConnectionPool::get(DB::ConnectionTimeouts const&, DB::Settings const&, bool) @ 0x000000003aaf0e2c 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:51: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadb565 20. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:108: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107], String const&, DB::Block const&, std::shared_ptr, std::shared_ptr, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::shared_ptr)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f28b236 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 22. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 23. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 24. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 25. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:02.729877 [ 16889 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:02.731103 [ 16889 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:02.739647 [ 16889 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:02.740799 [ 16889 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:03.198212 [ 3733 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_150_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.81 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column input_wait_elapsed_us): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_134_11/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromFileBase::ReadBufferFromFileBase(unsigned long, char*, unsigned long, std::optional) @ 0x000000001f9642f0 13. ./src/IO/ReadBufferFromFileDescriptor.h:47: DB::ReadBufferFromFileDescriptorPRead::ReadBufferFromFileDescriptorPRead(int, unsigned long, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002d1ae580 14. ./src/IO/ReadBufferFromFile.h:97: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002d1adc63 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002d1aca23 16. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002d1ac62b 17. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002fe351f5 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000395385be 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:101: DB::MergeTreeReaderStream::init() @ 0x0000000039edafdf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:171: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x0000000039ede64a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:327: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000039eeb876 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:516: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039ef0f93 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f589c85 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 27. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 28. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 30. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 31. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:03.200341 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_150_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.81 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column input_wait_elapsed_us): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_134_11/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromFileBase::ReadBufferFromFileBase(unsigned long, char*, unsigned long, std::optional) @ 0x000000001f9642f0 13. ./src/IO/ReadBufferFromFileDescriptor.h:47: DB::ReadBufferFromFileDescriptorPRead::ReadBufferFromFileDescriptorPRead(int, unsigned long, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002d1ae580 14. ./src/IO/ReadBufferFromFile.h:97: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002d1adc63 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002d1aca23 16. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002d1ac62b 17. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002fe351f5 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000395385be 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:101: DB::MergeTreeReaderStream::init() @ 0x0000000039edafdf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:171: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x0000000039ede64a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:327: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000039eeb876 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:516: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039ef0f93 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f589c85 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 27. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 28. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 30. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 31. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:03.708886 [ 19621 ] {4a796c3b-cf8d-4184-9587-9a5573fddefa} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 500.82 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46226) (comment: 02286_parallel_final.sh) (query 3, line 4) (in query: insert into tbl_8parts_16granules_seq select number, 1 from numbers_mt(1048576);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037b0e38e 12. ./build_docker/./src/Columns/IColumn.cpp:254: DB::IColumnHelper, DB::ColumnFixedSizeHelper>::scatter(unsigned long, DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003818ebd8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:369: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7bce0 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:27:03.739297 [ 19621 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 500.82 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037b0e38e 12. ./build_docker/./src/Columns/IColumn.cpp:254: DB::IColumnHelper, DB::ColumnFixedSizeHelper>::scatter(unsigned long, DB::PODArray, 63ul, 64ul> const&) const @ 0x000000003818ebd8 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:369: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039c7bce0 14. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:95: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a572fd2 15. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 23. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:27:03.746496 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 511.09 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:03.748797 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 511.09 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:03.983809 [ 18149 ] {32f6e9cb-6ac1-4b02-bef4-52ca46a121b5} executeQuery: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 0: while executing 'FUNCTION and(greater(__table1.user_id, 0_UInt8) :: 7, equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String) :: 2) -> and(greater(__table1.user_id, 0_UInt8), equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String)) UInt8 : 6'. (OPENSSL_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:43818) (comment: 01318_decrypt.sql) (query 66, line 142) (in query: SELECT dt, user_id FROM decrypt_null WHERE (user_id > 0) AND (decrypt('aes-256-gcm', '[HIDDEN]') = 'value2')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::OpenSSLDetails::onError(String) @ 0x0000000008c9b0ec 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39d050 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d3980af 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 11. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x0000000037522ca0 12. ./build_docker/./src/Columns/ColumnFunction.cpp:361: DB::ColumnFunction::reduce() const @ 0x000000003752251d 13. ./build_docker/./src/Columns/MaskOperations.cpp:285: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038249661 14. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeShortCircuit(std::vector>&, std::shared_ptr const&) const @ 0x000000002c2b7085 15. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c2a86b0 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 21. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:156: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003bb1b7a6 22. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:140: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003bb1b304 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 2025.11.13 09:27:04.005202 [ 18149 ] {} TCPHandler: Code: 454. DB::Exception: Failed to decrypt. OpenSSL error code: 0: while executing 'FUNCTION and(greater(__table1.user_id, 0_UInt8) :: 7, equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String) :: 2) -> and(greater(__table1.user_id, 0_UInt8), equals(decrypt('aes-256-gcm'_String, __table1.encrypted, 'keykeykeykeykeykeykeykeykeykey02'_String, __table1.iv), 'value2'_String)) UInt8 : 6'. (OPENSSL_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::OpenSSLDetails::onError(String) @ 0x0000000008c9b0ec 4. COW::immutable_ptr DB::FunctionDecrypt::doDecrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000d39d050 5. DB::FunctionDecrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d3980af 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 11. ./build_docker/./src/Columns/ColumnFunction.cpp:372: DB::ColumnFunction::reduce() const @ 0x0000000037522ca0 12. ./build_docker/./src/Columns/ColumnFunction.cpp:361: DB::ColumnFunction::reduce() const @ 0x000000003752251d 13. ./build_docker/./src/Columns/MaskOperations.cpp:285: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038249661 14. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeShortCircuit(std::vector>&, std::shared_ptr const&) const @ 0x000000002c2b7085 15. DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c2a86b0 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 21. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:156: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003bb1b7a6 22. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:140: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003bb1b304 23. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 24. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:04.065559 [ 18700 ] {c3902d9e-6028-43d3-bace-491b6f7f1367} executeQuery: Code: 57. DB::Exception: Table test_5.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02901_predicate_pushdown_cte_stateful.sql) (in query: /* ddl_entry=query-0000000175 */ CREATE TABLE test_5.t UUID '071f0305-339e-4523-97a3-69cba97702d5' (`rDate` String, `cpu_total` Int64) ENGINE = Log), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:04.089525 [ 18700 ] {c3902d9e-6028-43d3-bace-491b6f7f1367} executeQuery: Code: 57. DB::Exception: Table test_5.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46288) (comment: 02901_predicate_pushdown_cte_stateful.sql) (query 2, line 3) (in query: CREATE TABLE t ( `rDate` String, `cpu_total` Int64 ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:04.110208 [ 18700 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a911eb 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x0000000031a8aaf5 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x000000002fa5e9d3 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9db70c 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 17. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:04.144134 [ 17226 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:04.145646 [ 17226 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:04.151388 [ 3736 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_250_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:04.153550 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_250_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:04.167370 [ 3725 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_150_12} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.54 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column input_wait_elapsed_us): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_134_11/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromFileBase::ReadBufferFromFileBase(unsigned long, char*, unsigned long, std::optional) @ 0x000000001f9642f0 13. ./src/IO/ReadBufferFromFileDescriptor.h:47: DB::ReadBufferFromFileDescriptorPRead::ReadBufferFromFileDescriptorPRead(int, unsigned long, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002d1ae580 14. ./src/IO/ReadBufferFromFile.h:97: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002d1adc63 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002d1aca23 16. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002d1ac62b 17. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002fe351f5 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000395385be 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:101: DB::MergeTreeReaderStream::init() @ 0x0000000039edafdf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:171: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x0000000039ede64a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:327: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000039eeb876 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:516: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039ef0f93 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f589c85 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 27. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 28. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 30. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 31. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:04.169879 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_75_150_12}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.54 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column input_wait_elapsed_us): (while reading from part /var/lib/clickhouse/store/6c2/6c2b2379-cbea-4913-bb0c-c4bd6479aebe/202511_75_134_11/ in table system.processors_profile_log (6c2b2379-cbea-4913-bb0c-c4bd6479aebe) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromFileBase::ReadBufferFromFileBase(unsigned long, char*, unsigned long, std::optional) @ 0x000000001f9642f0 13. ./src/IO/ReadBufferFromFileDescriptor.h:47: DB::ReadBufferFromFileDescriptorPRead::ReadBufferFromFileDescriptorPRead(int, unsigned long, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002d1ae580 14. ./src/IO/ReadBufferFromFile.h:97: DB::ReadBufferFromFilePReadWithDescriptorsCache::ReadBufferFromFilePReadWithDescriptorsCache(String const&, unsigned long, int, char*, unsigned long, std::optional, std::shared_ptr) @ 0x000000002d1adc63 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long)::$_0::operator()(unsigned long, unsigned long, int) const @ 0x000000002d1aca23 16. ./build_docker/./src/Disks/IO/createReadBufferFromFileBase.cpp:213: DB::createReadBufferFromFileBase(String const&, DB::ReadSettings const&, std::optional, std::optional, int, char*, unsigned long) @ 0x000000002d1ac62b 17. ./build_docker/./src/Disks/DiskLocal.cpp:343: DB::DiskLocal::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x000000002fe351f5 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:131: DB::DataPartStorageOnDiskFull::readFile(String const&, DB::ReadSettings const&, std::optional, std::optional) const @ 0x00000000395385be 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:101: DB::MergeTreeReaderStream::init() @ 0x0000000039edafdf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderStream.cpp:171: DB::MergeTreeReaderStream::adjustRightMark(unsigned long) @ 0x0000000039ede64a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:327: DB::MergeTreeReaderWide::getStream(bool, DB::ISerialization::SubstreamPath const&, DB::MergeTreeDataPartChecksums const&, DB::NameAndTypePair const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&) @ 0x0000000039eeb876 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:516: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, DB::ReadBuffer* (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039ef0f93 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f589c85 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 27. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 28. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 30. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 31. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:04.181391 [ 17226 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:04.572315 [ 16354 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:05.567473 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_250_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 546.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:05.570212 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_250_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 546.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:05.575837 [ 3730 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 547.02 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:05.578321 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 547.02 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:05.978133 [ 9832 ] {967bcbd4-8fb4-40b0-b14a-9f7f7cc0dcad} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_v81kulz0.async_inserts (517ac423-7e02-4bac-9b16-12aa9bcd2a8d)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.8.10072.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO test_v81kulz0.async_inserts (id, s) FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000039a94997 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4991: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e777 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003a56f7fb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000316884ec 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031692bf8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:27:06.005762 [ 9832 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_v81kulz0.async_inserts (id, s) FORMAT JSONEachRow': Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_v81kulz0.async_inserts (517ac423-7e02-4bac-9b16-12aa9bcd2a8d)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000039a94997 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4991: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e777 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003a56f7fb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000316884ec 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031692bf8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.013219 [ 16354 ] {dcf9e8b7-1a46-420e-9987-eff62744c657} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_v81kulz0.async_inserts (517ac423-7e02-4bac-9b16-12aa9bcd2a8d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51484) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000039a94997 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4991: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e777 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003a56f7fb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000316884ec 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031692bf8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:27:06.013429 [ 16889 ] {b628752e-a411-434e-815e-28256647754e} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_v81kulz0.async_inserts (517ac423-7e02-4bac-9b16-12aa9bcd2a8d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51498) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000039a94997 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4991: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e777 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003a56f7fb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000316884ec 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031692bf8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:27:06.026156 [ 18700 ] {db6d0ab7-8272-4d0d-a913-3e43e897e2be} executeQuery: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_v81kulz0.async_inserts (517ac423-7e02-4bac-9b16-12aa9bcd2a8d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51482) (comment: 02015_async_inserts_5.sh) (in query: INSERT INTO async_inserts FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000039a94997 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4991: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e777 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003a56f7fb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000316884ec 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031692bf8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:27:06.038379 [ 16354 ] {dcf9e8b7-1a46-420e-9987-eff62744c657} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_v81kulz0.async_inserts (517ac423-7e02-4bac-9b16-12aa9bcd2a8d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000039a94997 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4991: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e777 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003a56f7fb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000316884ec 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031692bf8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.039750 [ 18700 ] {db6d0ab7-8272-4d0d-a913-3e43e897e2be} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_v81kulz0.async_inserts (517ac423-7e02-4bac-9b16-12aa9bcd2a8d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000039a94997 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4991: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e777 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003a56f7fb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000316884ec 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031692bf8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.089812 [ 16889 ] {b628752e-a411-434e-815e-28256647754e} DynamicQueryHandler: Code: 252. DB::Exception: Too many parts (1 with average size of 159.00 B) in table 'test_v81kulz0.async_inserts (517ac423-7e02-4bac-9b16-12aa9bcd2a8d)'. Merges are processing significantly slower than inserts: While executing WaitForAsyncInsert. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000039a94997 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:4991: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000003997e777 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:76: DB::MergeTreeSink::onStart() @ 0x000000003a56f7fb 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e4cf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d412 9. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 13. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 14. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:996: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000316884ec 15. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000031692bf8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.339593 [ 16889 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 496.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.364698 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_250_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 516.15 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.367854 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_250_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 516.15 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.796282 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 445.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.797448 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 445.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.824104 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 445.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.825342 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 445.12 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:06.966696 [ 16889 ] {2ec54c33-55ad-484a-bdb8-69bb106ab13f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57198) (comment: 02015_async_inserts_5.sh) (in query: DROP DATABASE IF EXISTS test_v81kulz0 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:27:06.975559 [ 16889 ] {2ec54c33-55ad-484a-bdb8-69bb106ab13f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:07.144120 [ 18721 ] {1c0639d6-38b9-4a1a-bddb-51b8b1a8fb37} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46408) (query 1, line 1) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038521118 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:27:07.154461 [ 18721 ] {} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000ae9e08a 4. ./build_docker/./src/Storages/StorageFile.cpp:1630: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038521118 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 7. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 8. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 12. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 13. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:27:08.002986 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_250_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 587.66 MiB (attempt to allocate chunk of 1.73 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:08.005512 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_250_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 587.66 MiB (attempt to allocate chunk of 1.73 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:08.087998 [ 4936 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 526.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:08.089234 [ 4936 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 526.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:08.256833 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 552.90 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:08.259598 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 552.90 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:09.116637 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_250_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 425.89 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:09.119027 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_250_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 425.89 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:09.226866 [ 18403 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 410.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:09.228063 [ 18403 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 410.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:09.291651 [ 18403 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 410.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:09.293807 [ 18403 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 410.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:09.639696 [ 17227 ] {99f983b8-0cee-4235-9cc5-ec86064e4ab8} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 2, line 3) (in query: SELECT * FROM (SELECT 1) FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:09.643365 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.23 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:09.645884 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.23 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:09.651971 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:09.706706 [ 17227 ] {3fd07308-14f8-48ed-83c0-6eb36820c54b} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 3, line 4) (in query: SELECT * FROM (SELECT 1) SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:09.716140 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:09.792200 [ 17227 ] {9dfdf87d-e3a0-4ad9-825c-cbd5448378f9} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 4, line 5) (in query: SELECT * FROM (SELECT 1) FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:09.802291 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:10.460543 [ 3736 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_251_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.07 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:10.463331 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_251_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.07 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:10.607830 [ 4936 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 411.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:10.642570 [ 4936 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 411.60 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:10.671829 [ 17226 ] {77d057b8-97f7-4250-af01-649d72fdfca0} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.87 MiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46450) (comment: 01651_lc_insert_tiny_log_3.sql) (query 4, line 6) (in query: INSERT INTO perf_lc_num (num) SELECT toUInt8(number) FROM numbers(10000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037adbe5e 12. DB::IColumn::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x000000002c15723f 13. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec073 14. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 15. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 24. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 2025.11.13 09:27:10.707768 [ 17226 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.87 MiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::reserve(unsigned long) @ 0x0000000037adbe5e 12. DB::IColumn::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x000000002c15723f 13. ./build_docker/./src/Interpreters/Squashing.cpp:175: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec073 14. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 15. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 16. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 19. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 24. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 27. ? @ 0x00007fa150622ac3 28. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:27:10.825110 [ 20389 ] {} ExternalDictionariesLoader: Could not load external dictionary '1119b8f4-92d2-4582-bb09-e8200cde5e0e', next update is scheduled at 2025-11-13 09:28:19: Code: 60. DB::Exception: Unknown table expression identifier 'test_9hufdy9z.dict_data' in scope SELECT key, v0, v1, v2, v3, v4 FROM test_9hufdy9z.dict_data. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000002702efa8 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x000000002702e915 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0a87 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:11.120138 [ 17227 ] {b777f25d-528e-41d4-9d15-00959d59baeb} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 5, line 7) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.139103 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.235601 [ 17227 ] {93334225-5257-46e8-83ab-9c32b424aa64} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 6, line 8) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.248868 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.284773 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 423.09 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:11.287837 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 423.09 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:11.303456 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.95 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:11.309170 [ 17227 ] {941d805e-496d-4adf-8ea7-5c5e36d4f022} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 7, line 9) (in query: WITH cte_subquery AS (SELECT 1) SELECT * FROM cte_subquery FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.320445 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.325911 [ 3729 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_251_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.98 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:11.362525 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_251_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.98 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:11.387956 [ 17227 ] {2e9909e1-d830-4de3-be26-3d3ec1611066} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 8, line 11) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.400759 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.468418 [ 4936 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.98 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:11.470510 [ 4936 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.98 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:11.492437 [ 18403 ] {2ebca2a1-8fb1-4f47-8481-d1e3cd84da85} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.98 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37210) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 1) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_without_merge' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.516122 [ 3739 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_158_10} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.96 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:11.516400 [ 18403 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.98 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.519033 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_158_10}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.96 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:11.530624 [ 18721 ] {40221ba5-7b0b-48a9-976e-c445cc031bde} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.98 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37188) (comment: 00834_kill_mutation_replicated_zookeeper.sh) (query 1, line 1) (in query: SELECT count() FROM system.mutations WHERE database = 'test_rr6dqsl7' AND table = 'kill_mutation_r1' AND is_done = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.530718 [ 17227 ] {7ba32ae6-a415-45ea-9393-384e0de00805} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 9, line 12) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.542443 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.556777 [ 18721 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.98 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.621638 [ 17227 ] {5062b5c1-5058-4064-a084-6537b9dc3922} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 10, line 13) (in query: SELECT * FROM (SELECT 1 UNION ALL SELECT 1) FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.631151 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery SELECT 1 UNION ALL SELECT 1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:903: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003036f0ed 5. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:164: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034c12a 6. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:182: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000303578e1 7. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:160: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000003034be22 8. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x000000003034a768 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc1b2 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.687183 [ 5803 ] {f044c59b-1493-4bbe-838c-bf88c96986b0} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.01 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37204) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toYYYYMMDD(d)=20201015;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.719840 [ 17227 ] {1392d05e-fa1e-49e1-a1da-7a4c96258fd4} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 11, line 15) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.732481 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.761992 [ 5803 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.01 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.860992 [ 17227 ] {c88d0e1f-108a-4324-b126-c8fea7a11c53} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 12, line 16) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.872103 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.972942 [ 17227 ] {78dc2972-8b33-4b45-ba61-54bdf75505b0} executeQuery: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46466) (comment: 02474_analyzer_subqueries_table_expression_modifiers.sql) (query 13, line 17) (in query: WITH cte_subquery AS (SELECT 1 UNION ALL SELECT 1) SELECT * FROM cte_subquery FINAL SAMPLE 1/2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:11.982534 [ 17227 ] {} TCPHandler: Code: 1. DB::Exception: Table expression modifiers FINAL SAMPLE 1 / 2 are not supported for subquery cte_subquery AS (SELECT 1 UNION ALL SELECT 1). (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4399: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b4cae 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:12.541992 [ 3724 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_251_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 475.99 MiB (attempt to allocate chunk of 1.60 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/data.bin (position: 340335, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 086cb579b4cfc1e7fdfe951fc3d2c77f82f0c8020000001000): (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:12.544430 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_251_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 475.99 MiB (attempt to allocate chunk of 1.60 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/data.bin (position: 340335, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 086cb579b4cfc1e7fdfe951fc3d2c77f82f0c8020000001000): (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:12.550338 [ 17376 ] {3de8fb4e-4824-4e1a-a6fe-68249fc74e30} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 475.41 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:46546) (comment: 03166_optimize_row_order_during_insert.sql) (query 11, line 38) (in query: INSERT INTO tab VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 2025.11.13 09:27:12.575877 [ 17376 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 475.41 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 2025.11.13 09:27:13.349131 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.351528 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.546258 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_251_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.74 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.548424 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_251_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.74 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.690171 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.04 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.691315 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.04 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.804565 [ 3727 ] {5a642d2d-8981-43c6-8ee1-d369be3bbe53::202511_1_166_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.64 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.54 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.807488 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5a642d2d-8981-43c6-8ee1-d369be3bbe53::202511_1_166_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.64 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.54 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.816151 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.54 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.817504 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.54 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.865959 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 15 entries up to offset 2346: Code: 241. DB::Exception: (total) memory limit exceeded: would use 415.79 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.893444 [ 17376 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 412.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.894743 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 412.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:13.896522 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 412.34 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:14.660207 [ 3737 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_158_10} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.06 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: (while reading column children): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_153_9/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 9167): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:14.663511 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_158_10}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.06 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: (while reading column children): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_153_9/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 9167): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.065771 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.42 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.068481 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.42 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.092531 [ 3724 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.42 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.096506 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.42 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.772979 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.73 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.775333 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.73 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.828478 [ 3736 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_146_31} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.831145 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_146_31}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.834083 [ 5803 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.835444 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.903509 [ 5803 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.904868 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:15.950814 [ 16132 ] {8a64e8a8-000d-4fdc-a4b1-2b713f181c8c} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.22 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37388) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where d >= '2020-09-01 00:00:00' and d<'2020-10-15 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:27:15.990823 [ 16132 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.22 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:16.648209 [ 16047 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:16.650102 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:16.662101 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.73 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:16.664569 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.73 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:16.761597 [ 16047 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:16.762926 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.248288 [ 3727 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_146_31} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 506.00 MiB (attempt to allocate chunk of 1.24 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.250470 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_146_31}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 506.00 MiB (attempt to allocate chunk of 1.24 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.362163 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 524.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.364632 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 524.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.387712 [ 3733 ] {205b8dc2-7b75-4374-9596-7f359671c6d7::202511_1_146_29} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.71 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b29a0d 13. ./src/Columns/IColumn.h:210: DB::ColumnTuple::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037779980 14. ./src/Columns/IColumn.h:210: DB::ColumnArray::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000370a3487 15. ./src/Columns/IColumn.h:210: DB::ColumnMap::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000375e6208 16. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.389702 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {205b8dc2-7b75-4374-9596-7f359671c6d7::202511_1_146_29}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.71 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b29a0d 13. ./src/Columns/IColumn.h:210: DB::ColumnTuple::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037779980 14. ./src/Columns/IColumn.h:210: DB::ColumnArray::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000370a3487 15. ./src/Columns/IColumn.h:210: DB::ColumnMap::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000375e6208 16. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.801957 [ 3736 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_146_31} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 439.26 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_145_30/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 1 with max_rows_to_read = 8235): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.806316 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.806314 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_146_31}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 439.26 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_145_30/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 1 with max_rows_to_read = 8235): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.808559 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.819761 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.831582 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.24 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.834551 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.24 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.847959 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.862377 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.906741 [ 15982 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.909021 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.923175 [ 17376 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.950865 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:17.952181 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.107073 [ 3730 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_146_31} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.109335 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_146_31}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.519454 [ 3903 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryLogElement]: Failed to flush system log system.query_log with 453 entries up to offset 65273: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.89 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 10. ./build_docker/./src/Columns/ColumnString.cpp:366: COW::immutable_ptr DB::ColumnString::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x000000003770981d 11. ./src/Columns/ColumnsCommon.h:136: DB::ColumnString::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000376e1f2f 12. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:47: DB::permuteBlockIfNeeded(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039829bfb 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:189: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba572d 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 26. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332cf2e1 27. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x00000000332cc91e 28. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fb9ba81 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fb9b8bf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.570951 [ 16693 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.572313 [ 16693 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.584595 [ 3729 ] {205b8dc2-7b75-4374-9596-7f359671c6d7::202511_1_146_29} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.18 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.586685 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {205b8dc2-7b75-4374-9596-7f359671c6d7::202511_1_146_29}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.18 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.648136 [ 10170 ] {154e5190-fb87-44c3-992f-bdf91bd44673} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.58 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37360) (comment: 00688_low_cardinality_in.sql) (query 14, line 15) (in query: INSERT INTO ary_lc_null VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:27:18.650215 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1373 entries up to offset 488220: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.67 MiB (attempt to allocate chunk of 4.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 10. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 11. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 12. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 13. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 27. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 28. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x000000003335e7be 29. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba3381 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba31bf 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.674318 [ 10170 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.58 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:27:18.741814 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 473.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.744479 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 473.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:18.825555 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5a642d2d-8981-43c6-8ee1-d369be3bbe53::202511_1_166_33}: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001f85446d 4. ./build_docker/./src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000001f84c969 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:146: CurrentMemoryTracker::injectFault() @ 0x000000001f62af1f 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:269: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000001f8efcd5 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a57ca6b 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a57949e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 11. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 13. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 14. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:19.409218 [ 16887 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:19.424076 [ 16198 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:19.426067 [ 16198 ] {} DynamicQueryHandler: Cannot send exception to client: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./build_docker/./src/Server/HTTPHandler.cpp:623: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace72e6 14. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:20.128624 [ 3736 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 533.64 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/data.bin (position: 131322, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 5eb818f0b924c5aa4793aae7179ce5c782acba000092550300): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:20.131034 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 533.64 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/data.bin (position: 131322, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 5eb818f0b924c5aa4793aae7179ce5c782acba000092550300): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:20.193077 [ 15982 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:20.194720 [ 15982 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:20.311393 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 532.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:20.315001 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 532.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:21.571087 [ 3734 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 509.74 MiB (attempt to allocate chunk of 1.27 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/query_id.bin (position: 25871, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: cce7287f0407dc75e31c89c08867d64282ff6400009ecc0500): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 15. DB::ReadBuffer::next() @ 0x0000000008ef7cef 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:21.573454 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 509.74 MiB (attempt to allocate chunk of 1.27 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/query_id.bin (position: 25871, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: cce7287f0407dc75e31c89c08867d64282ff6400009ecc0500): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 15. DB::ReadBuffer::next() @ 0x0000000008ef7cef 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:21.645396 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 488.57 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:21.648118 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 488.57 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.059068 [ 3726 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 477.33 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.061292 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 477.33 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.325321 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.326548 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.419473 [ 3732 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.423059 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.536914 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.38 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.539698 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.38 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.630496 [ 16141 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.631766 [ 16141 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.709003 [ 16141 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.710245 [ 16141 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.720615 [ 16887 ] {007ddce2-94d3-4768-a051-34788bd6b3d7} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56794) (comment: 00825_protobuf_format_nested_in_nested.sh) (query 4, line 7) (in query: SELECT `__table1`.`x.y` AS `x.y` FROM `test_9`.`nested_in_nested_protobuf_00825` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:22.740868 [ 16233 ] {d72748f5-1c90-41d0-b6a2-6c611994eb12} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50292) (comment: 00825_protobuf_format_nested_in_nested.sh) (query 4, line 7) (in query: SELECT `__table1`.`x.y` AS `x.y` FROM `test_9`.`nested_in_nested_protobuf_00825` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:22.744627 [ 16887 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:22.764513 [ 17752 ] {b6df6948-7581-475a-a9dd-83eb0f90f5d9} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 402.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34030) (comment: 00825_protobuf_format_nested_in_nested.sh) (query 4, line 7) (in query: SELECT * FROM nested_in_nested_protobuf_00825;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:22.779837 [ 16233 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:22.781974 [ 16233 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50292, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.783174 [ 16233 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50292, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:22.812535 [ 17752 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 402.70 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:23.227082 [ 16693 ] {07ea69a1-94c6-4f26-9f5b-e55fb852e61e} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.75 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34040) (comment: 02943_exprs_order_in_group_by_with_rollup.sql) (query 4, line 6) (in query: insert into test_group_by_with_rollup_order values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:27:23.300007 [ 16691 ] {45e3d081-b5ce-4e85-82d2-8f704abc8da8} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42074) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_11`.`tMM` AS `__table1` WHERE (`__table1`.`d` >= '2020-09-12 00:00:00') AND (`__table1`.`d` < '2020-10-16 00:00:00')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:23.305200 [ 16693 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.75 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:27:23.323183 [ 16691 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:23.333736 [ 19499 ] {3b524da5-1911-4c1f-906e-948d76fcf3c1} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: (total) memory limit exceeded: would use 427.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34054) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where d >= '2020-09-12 00:00:00' and d < '2020-10-16 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:23.363052 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.73 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:23.365626 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_252_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.73 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:23.377742 [ 19499 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: (total) memory limit exceeded: would use 427.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:23.586922 [ 16141 ] {bf28a5d2-ad4a-4fbb-8774-94e9ebfd59e5} executeQuery: Code: 60. DB::Exception: Table test_1.alter_00427 does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34088) (comment: 00427_alter_primary_key.sh) (query 1, line 1) (in query: INSERT INTO alter_00427 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:27:23.608394 [ 16141 ] {} TCPHandler: Code: 60. DB::Exception: Table test_1.alter_00427 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:27:23.866491 [ 19499 ] {5b781493-0eea-47fc-b3c9-f6b16e566bfb} executeQuery: Code: 57. DB::Exception: Table test_9.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34102) (comment: 01107_join_right_table_totals.sql) (query 2, line 2) (in query: CREATE TABLE t (`item_id` UInt64, `price_sold` Float32, `date` Date) ENGINE = MergeTree ORDER BY item_id SETTINGS index_granularity = 41144, min_bytes_for_wide_part = 69520061, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 24, min_bytes_for_full_part_storage = 317784217, compact_parts_max_bytes_to_buffer = 308880785, compact_parts_max_granules_to_buffer = 162, compact_parts_merge_max_bytes_to_prefetch_part = 22566000, merge_max_block_size = 1875, old_parts_lifetime = 141., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5628403885, index_granularity_bytes = 11968781, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 90258, primary_key_compress_block_size = 95239, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:27:23.886987 [ 19499 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:27:23.891267 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.27 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:23.893662 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.27 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.097936 [ 3739 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_253_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.41 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.097982 [ 3727 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_147_32} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.37 MiB (attempt to allocate chunk of 1.32 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000377819cd 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 21. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 23. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 24. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 25. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375e8ff1 27. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 28. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 30. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.100505 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_147_32}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.37 MiB (attempt to allocate chunk of 1.32 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000377819cd 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 21. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 23. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 24. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 25. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375e8ff1 27. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 28. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 30. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.103556 [ 18392 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.171272 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_253_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.41 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.368384 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 439.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.369884 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 439.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.539964 [ 17752 ] {66ecd7d2-6658-45bb-967b-a9bdb1856049} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.91 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34110) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where d >= '2020-09-12 00:00:00' and d < '2020-10-16 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:27:24.583829 [ 3731 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_147_32} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 439.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.586578 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_147_32}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 439.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.640329 [ 17752 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.91 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:24.949955 [ 3724 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.05 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column lines): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:566: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69b3a2 15. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.953769 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.05 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column lines): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:566: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69b3a2 15. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.956989 [ 3735 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_147_32} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.46 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:24.959972 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_147_32}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.46 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:25.158795 [ 18392 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:25.160039 [ 18392 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:25.622112 [ 16047 ] {045b88c8-cbf0-4ab5-86dd-8828b84e0f71} executeQuery: Code: 36. DB::Exception: Function icebergTruncate accepts only positive width: In scope SELECT icebergTruncate(0, 55). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37464) (comment: 03376_iceberg_truncate.sql) (query 37, line 45) (in query: SELECT icebergTruncate(0, 55);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000116b14af 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:27:25.632021 [ 16047 ] {} TCPHandler: Code: 36. DB::Exception: Function icebergTruncate accepts only positive width: In scope SELECT icebergTruncate(0, 55). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000116b14af 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 27. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 28. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 30. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 2025.11.13 09:27:25.968629 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 545.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:25.969961 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 545.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:25.973082 [ 3739 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_147_32} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 544.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:25.976729 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_147_32}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 544.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:26.016473 [ 17752 ] {4fedc061-0962-405d-91f3-99e7935880ae} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 541.14 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34164) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toStartOfDay(d) >= '2020-09-12 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:27:26.049291 [ 17752 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 541.14 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:26.069369 [ 3729 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_253_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 542.21 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:26.072617 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_253_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 542.21 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:26.135405 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 543.28 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:26.138258 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 543.28 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:26.869258 [ 3724 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_147_32} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.49 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_146_31/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 2 with max_rows_to_read = 5422): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037ae594e 12. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037c869b9 13. ./src/Columns/ColumnsCommon.h:121: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037af981f 14. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037af962e 15. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:268: DB::ColumnLowCardinality::insertRangeFromDictionaryEncodedColumn(DB::IColumn const&, DB::IColumn const&) @ 0x0000000037540706 16. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:612: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69cda4 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 27. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:26.870878 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_253_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.64 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:26.871863 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_147_32}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.49 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_146_31/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 2 with max_rows_to_read = 5422): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037ae594e 12. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037c869b9 13. ./src/Columns/ColumnsCommon.h:121: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037af981f 14. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037af962e 15. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:268: DB::ColumnLowCardinality::insertRangeFromDictionaryEncodedColumn(DB::IColumn const&, DB::IColumn const&) @ 0x0000000037540706 16. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:612: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69cda4 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 27. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 28. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:26.873901 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_253_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.64 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:27.073537 [ 2997 ] {48dbfc47-2784-4afa-a65d-716f28954b48} executeQuery: Code: 60. DB::Exception: Could not find table: alter_00427. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34234) (comment: 00427_alter_primary_key.sh) (query 1, line 1) (in query: ALTER TABLE alter_00427 MODIFY COLUMN c UInt32), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:27:27.091045 [ 2997 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: alter_00427. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:27:27.481115 [ 16047 ] {ca8e77c7-b572-4ffe-8623-33d0a1a160ff} executeQuery: Code: 43. DB::Exception: First argument should be UInt data type: In scope SELECT icebergTruncate(-1, 55). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37464) (comment: 03376_iceberg_truncate.sql) (query 38, line 46) (in query: SELECT icebergTruncate(-1, 55);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000116b5931 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:27:27.492940 [ 16047 ] {} TCPHandler: Code: 43. DB::Exception: First argument should be UInt data type: In scope SELECT icebergTruncate(-1, 55). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000116b5931 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:27:27.789947 [ 3730 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 488.96 MiB (attempt to allocate chunk of 4.39 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column trace): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:27.792445 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 488.96 MiB (attempt to allocate chunk of 4.39 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column trace): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:28.244867 [ 18392 ] {6f456894-13a3-466e-b506-e9e1ab00dcc4} executeQuery: Code: 60. DB::Exception: Table test_1.alter_00427 does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34274) (comment: 00427_alter_primary_key.sh) (query 1, line 1) (in query: INSERT INTO alter_00427 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:27:28.266878 [ 18392 ] {} TCPHandler: Code: 60. DB::Exception: Table test_1.alter_00427 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000032ac3054 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000032adee2f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:27:28.408551 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_253_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 473.78 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:28.411204 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_253_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 473.78 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:28.560535 [ 18106 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:28.562869 [ 18106 ] {} DynamicQueryHandler: Cannot send exception to client: Code: 241. DB::Exception: (total) memory limit exceeded: would use 485.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./build_docker/./src/Server/HTTPHandler.cpp:623: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace72e6 14. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:28.774307 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.17 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:28.777094 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 482.17 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:29.012299 [ 16047 ] {eed79352-713c-4918-84c7-f67a030cfcde} executeQuery: Code: 43. DB::Exception: Second argument must be of native integer type, String/FixedString, Decimal: In scope SELECT icebergTruncate(3, 0.). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37464) (comment: 03376_iceberg_truncate.sql) (query 39, line 47) (in query: SELECT icebergTruncate(3, 0.0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000116b5e91 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:27:29.024294 [ 16047 ] {} TCPHandler: Code: 43. DB::Exception: Second argument must be of native integer type, String/FixedString, Decimal: In scope SELECT icebergTruncate(3, 0.). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. DB::(anonymous namespace)::FunctionIcebergTruncate::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000116b5e91 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c10f06 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:27:29.376943 [ 2997 ] {2384aa72-0053-42ec-bdc3-cc3ac946dda8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'alter_00427' in scope SELECT d FROM alter_00427 WHERE a = 'bar'. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34310) (comment: 00427_alter_primary_key.sh) (query 1, line 1) (in query: SELECT d FROM alter_00427 WHERE a = 'bar'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:29.398482 [ 2997 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'alter_00427' in scope SELECT d FROM alter_00427 WHERE a = 'bar'. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:27:29.656099 [ 3724 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 499.10 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:29.659223 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 499.10 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:30.141433 [ 16344 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:30.143385 [ 16344 ] {} DynamicQueryHandler: Cannot send exception to client: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./build_docker/./src/Server/HTTPHandler.cpp:623: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace72e6 14. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:30.208505 [ 19619 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:30.210166 [ 19619 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:30.498310 [ 3727 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:30.502324 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:30.510979 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:30.579064 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:30.639525 [ 3732 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.76 MiB (attempt to allocate chunk of 1.46 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_74_74_0/data.bin (position: 65505, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 48fa54b8325afe91b28909b63203d8cf82006f000028a70c00): (while reading column trace): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_74_74_0/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 2850): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b006e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:30.642088 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.76 MiB (attempt to allocate chunk of 1.46 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_74_74_0/data.bin (position: 65505, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 48fa54b8325afe91b28909b63203d8cf82006f000028a70c00): (while reading column trace): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_74_74_0/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 2850): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b006e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:31.317522 [ 19606 ] {78eb82b1-98f0-4bb2-80a6-98a60cd438b1} executeQuery: Code: 60. DB::Exception: Table test_1.alter_00427 does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58434) (comment: 00427_alter_primary_key.sh) (query 1, line 1) (in query: DROP TABLE alter_00427), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:27:31.331948 [ 19606 ] {} TCPHandler: Code: 60. DB::Exception: Table test_1.alter_00427 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:27:32.073387 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 441.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:32.080818 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 441.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:32.106525 [ 3724 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:32.109367 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:32.124822 [ 17383 ] {09e2de0a-cdf0-4ed2-8c61-945b18e92fdd} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56804) (comment: 00872_t64_bit_codec.sql) (query 6, line 19) (in query: SELECT `__table1`.`u8` AS `u8`, `__table1`.`t_u8` AS `t_u8`, `__table1`.`u16` AS `u16`, `__table1`.`t_u16` AS `t_u16`, `__table1`.`u32` AS `u32`, `__table1`.`t_u32` AS `t_u32`, `__table1`.`u64` AS `u64`, `__table1`.`t_u64` AS `t_u64` FROM `test_9`.`t64` AS `__table1` ORDER BY `__table1`.`u64` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:32.157738 [ 18392 ] {fa95194a-e128-464c-9bad-200618705638} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 433.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34326) (comment: 00872_t64_bit_codec.sql) (query 6, line 19) (in query: SELECT * FROM t64 ORDER BY u64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:32.159959 [ 17383 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:32.193049 [ 18392 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 433.33 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:32.638541 [ 3726 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:32.641154 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:32.954937 [ 3732 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 441.08 MiB (attempt to allocate chunk of 1.93 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 16. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000377819cd 18. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 19. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 20. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 22. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 23. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 24. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375e8ff1 26. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 27. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 28. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:32.958029 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 441.08 MiB (attempt to allocate chunk of 1.93 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 16. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000377819cd 18. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 19. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 20. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 22. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 23. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 24. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375e8ff1 26. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 27. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 28. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.200168 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 466.05 MiB (attempt to allocate chunk of 1.66 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 8750): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.200856 [ 17268 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.202304 [ 17268 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 465.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.202501 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 466.05 MiB (attempt to allocate chunk of 1.66 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 1 with max_rows_to_read = 8750): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.534252 [ 3724 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.536701 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.86 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.557206 [ 3736 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.21 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.559191 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.21 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.644626 [ 16203 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.645971 [ 16203 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.694093 [ 3739 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.09 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.697669 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.09 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.702520 [ 16203 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.09 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.703851 [ 16203 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.09 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:33.771972 [ 19606 ] {b153c066-df42-444c-a5d1-b625ad13a8d2} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.56 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58518) (comment: 02030_function_mapContainsKeyLike.sql) (query 3, line 5) (in query: INSERT INTO map_containsKeyLike_test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 2025.11.13 09:27:33.791070 [ 19606 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.56 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 30. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 2025.11.13 09:27:34.088503 [ 3724 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.83 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.092003 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.83 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.105994 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.108440 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.319983 [ 16203 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.07 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.321639 [ 16203 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.07 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.358200 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.09 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.360874 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.09 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.533146 [ 3728 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.10 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.535635 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.10 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.632629 [ 3912 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryMetricLogElement]: Failed to flush system log system.query_metric_log with 8 entries up to offset 5119: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.05 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037b1704e 10. ./src/Common/COW.h:293: DB::ColumnVector::cloneResized(unsigned long) const @ 0x0000000037b28bc1 11. DB::IColumn::cloneEmpty() const @ 0x000000002c156c44 12. ./build_docker/./src/Core/ColumnWithTypeAndName.cpp:21: DB::ColumnWithTypeAndName::cloneEmpty() const @ 0x000000002eb2689a 13. ./build_docker/./src/Core/Block.cpp:502: DB::Block::cloneEmpty() const @ 0x000000002eaff97e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:579: DB::MergeTreeDataPartWriterOnDisk::initOrAdjustDynamicStructureIfNeeded(DB::Block&) @ 0x0000000039bd16ae 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:177: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba565f 16. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 20. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 28. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000333e0dcc 29. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x00000000333de236 30. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba9d61 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba9b9f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.766879 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1243 entries up to offset 492240: Code: 241. DB::Exception: (total) memory limit exceeded: would use 468.39 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 10. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 11. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 12. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 13. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 14. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 16. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 20. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 28. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 29. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x000000003335e7be 30. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba3381 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba31bf (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.850462 [ 3726 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.853991 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.891259 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:34.940237 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:35.111946 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:35.114477 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.89 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:35.346053 [ 3727 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.07 MiB (attempt to allocate chunk of 1.09 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column finish_time_us): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_147_32/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 0 with max_rows_to_read = 8230): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:35.348037 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.07 MiB (attempt to allocate chunk of 1.09 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column finish_time_us): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_147_32/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 0 with max_rows_to_read = 8230): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:35.358983 [ 17228 ] {b3cef775-9517-409c-8322-554947e6001e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58592) (comment: 02287_type_object_convert.sql) (query 1, line 3) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:27:35.373808 [ 17228 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000002e6b093b 7. ./build_docker/./src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000317ed375 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x0000000032da59d4 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:27:35.458779 [ 3736 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.95 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:35.460881 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.95 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:35.507729 [ 3730 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.10 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:35.510243 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.10 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.110361 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.66 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.114465 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_116_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.66 MiB (attempt to allocate chunk of 1.25 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.132161 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.48 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.134678 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.48 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.242873 [ 18728 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 410.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.243947 [ 18728 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 410.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.246881 [ 3726 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 411.08 MiB (attempt to allocate chunk of 1.59 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000377819cd 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 21. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 23. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 24. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 25. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375e8ff1 27. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 28. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 30. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.249067 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 411.08 MiB (attempt to allocate chunk of 1.59 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000377819cd 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 21. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 23. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 24. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 25. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375e8ff1 27. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 28. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 30. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.279381 [ 3729 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.35 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.281583 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.35 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.499580 [ 19619 ] {f0c78c01-c0bb-4279-9555-b2fcc645d75a} executeQuery: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function greatest: In scope SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58466) (comment: 01440_big_int_least_greatest.sql) (query 7, line 33) (in query: SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001157535c 5. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010e3f7a3 6. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010e3c94c 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:27:36.509594 [ 19619 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function greatest: In scope SELECT least(toUInt32(0), toInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001157535c 5. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010e3f7a3 6. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)1, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000010e3c94c 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:27:36.651546 [ 3733 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.653779 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.709391 [ 16203 ] {0d625f5d-de98-48ef-a402-4b24d0962d84} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.61 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58622) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toStartOfDay(d) >= '2020-09-15 00:00:00' and d < '2020-10-16 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9c535 14. ./build_docker/./src/Client/Connection.cpp:1133: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003aaa30f1 15. ./build_docker/./src/Client/MultiplexedConnections.cpp:119: DB::MultiplexedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x000000003ab97fb2 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:928: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002f27ba1e 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:441: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278249 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 19. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 20. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 21. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:36.724006 [ 18728 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40406, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.725079 [ 18728 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40406, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:36.745339 [ 16203 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.61 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9c535 14. ./build_docker/./src/Client/Connection.cpp:1133: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003aaa30f1 15. ./build_docker/./src/Client/MultiplexedConnections.cpp:119: DB::MultiplexedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x000000003ab97fb2 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:928: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002f27ba1e 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:441: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278249 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 19. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 20. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 21. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:36.998194 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.74 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.000751 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.74 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.088454 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 14 entries up to offset 2384: Code: 241. DB::Exception: (total) memory limit exceeded: would use 405.55 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.125356 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.126610 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.422848 [ 3735 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_101_18} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_99_99_0/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 16): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.424959 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_101_18}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_99_99_0/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 16): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.458801 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.460214 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.736823 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.738866 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.784198 [ 3738 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.74 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.786867 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.74 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.814274 [ 18149 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.815572 [ 18149 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.969973 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.11 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:37.972006 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.11 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.085183 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.97 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.086561 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.97 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.213271 [ 19621 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.214547 [ 19621 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.292210 [ 19619 ] {86edab46-8869-4956-9641-8c4eeaba21e8} executeQuery: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function least: In scope SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58466) (comment: 01440_big_int_least_greatest.sql) (query 8, line 34) (in query: SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001330aabc 5. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012be21a3 6. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012bdfb6c 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:27:38.300864 [ 19619 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Int32 and UInt256 of arguments of function least: In scope SELECT least(toInt32(0), toUInt256(0)), greatest(toInt32(0), toUInt256(0)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008e3e217 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000001330aabc 5. DB::FunctionBinaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012be21a3 6. DB::LeastGreatestOverloadResolver<(DB::LeastGreatest)0, DB::FunctionBinaryArithmetic>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012bdfb6c 7. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a25f1e6 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 26. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 27. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 29. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 2025.11.13 09:27:38.455816 [ 3737 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_170_44} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.51 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.457978 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_170_44}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.51 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.475425 [ 3735 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.46 MiB (attempt to allocate chunk of 1.09 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column finish_time_us): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_147_32/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 0 with max_rows_to_read = 8230): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.477814 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_148_33}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.46 MiB (attempt to allocate chunk of 1.09 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column finish_time_us): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_147_32/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 0 with max_rows_to_read = 8230): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.478623 [ 18700 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.481880 [ 16889 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.486880 [ 3733 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.67 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.488961 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.67 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.940039 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.71 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:38.942319 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.71 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:40.000958 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 499.99 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:40.003776 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 499.99 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:40.111779 [ 3727 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 499.99 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:40.114441 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_254_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 499.99 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:40.741282 [ 19621 ] {16477eac-115d-41e0-9a80-957b8da31235} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAny('123', ['12']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 5, line 9) (in query: select multiMatchAny('123', ['12']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107d11d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:40.751282 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAny('123', ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107d11d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:40.874838 [ 17390 ] {733d8ada-5089-45b2-a0ba-762385a4d708} executeQuery: Code: 731. DB::Exception: use_query_cache and overflow_mode != 'throw' cannot be used together. (QUERY_CACHE_USED_WITH_NON_THROW_OVERFLOW_MODE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58762) (comment: 02915_analyzer_fuzz_5.sql) (query 5, line 5) (in query: SELECT 'limit w/ GROUP BY', count(NULL), number FROM remote('127.{1,2}', view(SELECT intDiv(number, 2147483647) AS number FROM numbers(10))) GROUP BY number WITH ROLLUP ORDER BY count() ASC, number DESC NULLS LAST SETTINGS limit = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033836774 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:27:40.968998 [ 17390 ] {} TCPHandler: Code: 731. DB::Exception: use_query_cache and overflow_mode != 'throw' cannot be used together. (QUERY_CACHE_USED_WITH_NON_THROW_OVERFLOW_MODE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033836774 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:27:41.032774 [ 18700 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.034704 [ 18700 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.043487 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 481.23 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.046114 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 481.23 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.196982 [ 18149 ] {991ccc0e-5c6d-4365-aab1-e089ef1e9dcc} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 481.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58760) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toYYYYMM(d) between 202009 and 202010 and toStartOfDay(d) = '2020-10-01 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9c535 14. ./build_docker/./src/Client/Connection.cpp:1133: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003aaa30f1 15. ./build_docker/./src/Client/MultiplexedConnections.cpp:119: DB::MultiplexedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x000000003ab97fb2 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:928: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002f27ba1e 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:441: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278249 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 19. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 20. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 21. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:41.216237 [ 18728 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:55290, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.217327 [ 18728 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:55290, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.244223 [ 18149 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 481.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9c535 14. ./build_docker/./src/Client/Connection.cpp:1133: DB::Connection::sendExternalTablesData(std::vector>, std::allocator>>>&) @ 0x000000003aaa30f1 15. ./build_docker/./src/Client/MultiplexedConnections.cpp:119: DB::MultiplexedConnections::sendExternalTablesData(std::vector>, std::allocator>>>, std::allocator>, std::allocator>>>>>&) @ 0x000000003ab97fb2 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:928: DB::RemoteQueryExecutor::sendExternalTables() @ 0x000000002f27ba1e 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:441: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278249 18. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 19. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 20. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 21. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:41.618463 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.619809 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.803714 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.805013 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.811855 [ 18728 ] {42dfc4d9-4cb4-42d3-b4a8-3891fb6af01a} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.17 MiB (attempt to allocate chunk of 1.63 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50846) (comment: 02163_shard_num.sql) (query 1, line 1) (in query: -- { echoOn } SELECT shardNum() AS shard_num, sum(1) as rows FROM remote('127.{1,2}', system, one) GROUP BY _shard_num ORDER BY _shard_num;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 18. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:41.866522 [ 18728 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 437.17 MiB (attempt to allocate chunk of 1.63 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 18. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:41.987172 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:41.988201 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.145367 [ 18149 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.157986 [ 18700 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 447.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.158996 [ 18700 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 447.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.202120 [ 18728 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 447.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.203950 [ 18728 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 447.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.208779 [ 3727 ] {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_151_156_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 447.85 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.211056 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6c2b2379-cbea-4913-bb0c-c4bd6479aebe::202511_151_156_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 447.85 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.224450 [ 18728 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 446.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.226033 [ 18728 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 446.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.252844 [ 18728 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 446.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.253965 [ 18728 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 446.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.269692 [ 18728 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 445.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.270770 [ 18728 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 445.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.277591 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.279629 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.288134 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.76 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.290097 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.76 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.312818 [ 18728 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.316296 [ 18728 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.324674 [ 18149 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 438.76 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.677338 [ 3736 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 481.20 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037ae594e 12. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037c869b9 13. ./src/Columns/ColumnsCommon.h:121: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037af981f 14. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037af962e 15. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:951: DB::ColumnLowCardinality::Dictionary::compact(DB::IColumnUnique const&, COW::mutable_ptr&) @ 0x000000003754d53f 16. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:590: DB::ColumnLowCardinality::cutAndCompact(unsigned long, unsigned long) const @ 0x000000003754d084 17. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:469: DB::SerializationLowCardinality::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f697c6d 18. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:434: DB::MergeTreeDataPartWriterWide::writeSingleGranule(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::shared_ptr&, DB::ISerialization::SerializeBinaryBulkSettings&, DB::Granule const&) @ 0x0000000039be9bc7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:498: DB::MergeTreeDataPartWriterWide::writeColumn(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::vector> const&) @ 0x0000000039be6529 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:343: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039be1a84 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.679661 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 481.20 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037ae594e 12. ./src/Common/COW.h:293: COW::immutable_ptr DB::ColumnVector::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037c869b9 13. ./src/Columns/ColumnsCommon.h:121: COW::immutable_ptr DB::selectIndexImpl>(DB::ColumnVector const&, DB::IColumn const&, unsigned long) @ 0x0000000037af981f 14. ./build_docker/./src/Columns/ColumnVector.cpp:766: DB::ColumnVector::index(DB::IColumn const&, unsigned long) const @ 0x0000000037af962e 15. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:951: DB::ColumnLowCardinality::Dictionary::compact(DB::IColumnUnique const&, COW::mutable_ptr&) @ 0x000000003754d53f 16. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:590: DB::ColumnLowCardinality::cutAndCompact(unsigned long, unsigned long) const @ 0x000000003754d084 17. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:469: DB::SerializationLowCardinality::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f697c6d 18. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:340: DB::SerializationArray::serializeBinaryBulkWithMultipleStreams(DB::IColumn const&, unsigned long, unsigned long, DB::ISerialization::SerializeBinaryBulkSettings&, std::shared_ptr&) const @ 0x000000002f5aeac9 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:434: DB::MergeTreeDataPartWriterWide::writeSingleGranule(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::shared_ptr&, DB::ISerialization::SerializeBinaryBulkSettings&, DB::Granule const&) @ 0x0000000039be9bc7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:498: DB::MergeTreeDataPartWriterWide::writeColumn(DB::NameAndTypePair const&, DB::IColumn const&, std::set, std::allocator>&, std::vector> const&) @ 0x0000000039be6529 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:343: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039be1a84 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:42.686179 [ 19621 ] {5778c4c2-4135-4137-add1-7121e94ff698} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAny('123', ['1', '2']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 6, line 10) (in query: select multiMatchAny('123', ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107d11d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:42.694446 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAny('123', ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107d11d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:43.499344 [ 3732 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.82 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:43.503468 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 498.82 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:43.531225 [ 3724 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 499.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:43.533504 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 499.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.524800 [ 19621 ] {aa7bb2d8-9ab3-45ff-b12e-7fb1dbee167e} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['12']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 8, line 13) (in query: select multiMatchAnyIndex('123', ['12']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c78c0e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:44.525824 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.89 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.529041 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.89 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.536276 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c78c0e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:44.583783 [ 3725 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.36 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.586868 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.36 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.617579 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.621403 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.45 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.777830 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.779154 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.896557 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 15 entries up to offset 2399: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.50 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.924201 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.40 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:44.926769 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.40 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.052306 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.054278 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.167586 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.52 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.170350 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.52 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.249437 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1214 entries up to offset 495004: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.81 MiB (attempt to allocate chunk of 4.41 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 10. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 11. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 12. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 13. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 27. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 28. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x000000003335e7be 29. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba3381 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba31bf 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.558070 [ 3727 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.41 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.49 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.561480 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.41 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.49 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.569908 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.47 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.571537 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.41 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.47 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.636027 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.46 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.638956 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.46 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.836882 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.46 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:45.838229 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.46 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.51 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.026444 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.47 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.027831 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.47 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.47 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.061043 [ 19621 ] {122aef79-a345-49a6-b910-3d87bf3c3967} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['1', '2']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 9, line 14) (in query: select multiMatchAnyIndex('123', ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c78c0e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:46.061456 [ 18700 ] {4befd2dc-3c2b-46d0-9c02-39a23462cdd7} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.36 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.47 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51024) (comment: 02790_keyed_hash_bug.sql) (query 1, line 1) (in query: --- previously caused MemorySanitizer: use-of-uninitialized-value, because we tried to read hash key from empty tuple column during interpretation SELECT sipHash64Keyed((1111111111111111111, toUInt64(222222222222223))) group by toUInt64(222222222222223);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:27:46.074290 [ 19618 ] {abf4bade-407a-4ce7-80fd-42aad1eab700} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.47 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52902) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_11`.`tMM` AS `__table1` WHERE (`__table1`.`d` >= '2020-10-01 00:00:00') AND (toStartOfDay(`__table1`.`d`) < '2020-10-02 00:00:00')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:27:46.078327 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAnyIndex('123', ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c78c0e 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:46.078982 [ 3738 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.082061 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.095390 [ 18700 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.36 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.47 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:46.101270 [ 4170 ] {c0e7a359-0343-403f-aecd-8a739af03c0e} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.48 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51018) (comment: 03156_dynamic_type_concurrent_inserts.sh) (query 1, line 1) (in query: SELECT dynamicType(d) t, count(), uniqExact(d) FROM test_cc GROUP BY t ORDER BY t), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:27:46.106880 [ 19618 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.47 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:46.106568 [ 17390 ] {e2c5a26e-b534-4a85-938c-3f6552dc3aa5} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: (total) memory limit exceeded: would use 382.47 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50996) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toYYYYMM(d) > 202009 and toStartOfDay(d) < '2020-10-02 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:46.135773 [ 4170 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.48 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:46.143299 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.88 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.164157 [ 17390 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: (total) memory limit exceeded: would use 382.47 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:46.638466 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.641090 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.693000 [ 17390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.694164 [ 17390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.717173 [ 3735 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.60 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.720093 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.60 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.922235 [ 3730 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.56 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/42e/42e4c43f-6d1d-497c-bdaf-685199a73f25/202511_1_170_44/data.bin (position: 152801, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: a65a1e2618662e97354bea8dd4f9ec5082c757010015450400): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/42e/42e4c43f-6d1d-497c-bdaf-685199a73f25/202511_1_170_44/ in table system.transactions_info_log (42e4c43f-6d1d-497c-bdaf-685199a73f25) located on disk default of type local, from mark 0 with max_rows_to_read = 8229): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.925368 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.56 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/42e/42e4c43f-6d1d-497c-bdaf-685199a73f25/202511_1_170_44/data.bin (position: 152801, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: a65a1e2618662e97354bea8dd4f9ec5082c757010015450400): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/42e/42e4c43f-6d1d-497c-bdaf-685199a73f25/202511_1_170_44/ in table system.transactions_info_log (42e4c43f-6d1d-497c-bdaf-685199a73f25) located on disk default of type local, from mark 0 with max_rows_to_read = 8229): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.938698 [ 18700 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.940192 [ 18700 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.957032 [ 18700 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.958144 [ 18700 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.988699 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:46.989974 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.319335 [ 18700 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.360384 [ 3724 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 415.90 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.362701 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 415.90 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.367340 [ 3728 ] {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_148_30} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.66 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.372292 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {862d992f-3cae-4444-b7e1-75a2b2ea814d::202511_1_148_30}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.66 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.666999 [ 16186 ] {fbee0768-4b89-4c18-af37-0762240b56f7} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.76 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:32786) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_11`.`tMM` AS `__table1` WHERE (`__table1`.`d` >= '2020-10-01 00:00:00') AND (toStartOfDay(`__table1`.`d`) < '2020-10-02 00:00:00')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:47.694803 [ 16186 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.76 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:47.728778 [ 3732 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.730986 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.783159 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.784386 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.792079 [ 3727 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.794321 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.21 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.802125 [ 16889 ] {d6fc7590-3bd3-44c6-a614-d5aa9fdf288f} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: (total) memory limit exceeded: would use 379.76 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:51104) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toYYYYMM(d) > 202009 and toStartOfDay(d) < '2020-10-02 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:47.830948 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.832319 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.866779 [ 16889 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: (total) memory limit exceeded: would use 379.76 MiB (attempt to allocate chunk of 1.10 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:47.924929 [ 3725 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:47.928242 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.48 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:48.059464 [ 19621 ] {4eec1721-32c9-475b-9bb8-cd956eddb67c} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['12']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 11, line 17) (in query: select multiMatchAllIndices('123', ['12']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6bc43 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:48.070147 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6bc43 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:48.105128 [ 17226 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:48.106375 [ 17226 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:48.595327 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 392.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:48.597251 [ 3737 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.26 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:48.597502 [ 17226 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:48.597989 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 392.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:48.599103 [ 17226 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:48.600265 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.26 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:48.667942 [ 16920 ] {f261dae6-549d-4486-9dd7-c16a59a287e8} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:54174). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54174) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_11`.`tMM` AS `__table1` WHERE (`__table1`.`d` >= '2020-10-01 00:00:00') AND (toStartOfDay(`__table1`.`d`) < '2020-10-02 00:00:00')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:728: DB::TCPHandler::runImpl() @ 0x000000003aea4c36 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:27:48.685103 [ 16920 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:54174). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:728: DB::TCPHandler::runImpl() @ 0x000000003aea4c36 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:27:48.744147 [ 3736 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:48.746437 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.92 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.034940 [ 3737 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.10 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.037800 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.10 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.133793 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.135255 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.462407 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.466388 [ 17390 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.468443 [ 17390 ] {} DynamicQueryHandler: Cannot send exception to client: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./build_docker/./src/Server/HTTPHandler.cpp:623: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace72e6 14. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.469227 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_255_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.509490 [ 3728 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 377.87 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.512076 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_171_45}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 377.87 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.515730 [ 18721 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.38 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:49.710114 [ 19621 ] {e70c1666-f08b-4ffa-9e61-81f2f17e7099} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['1', '2']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 12, line 18) (in query: select multiMatchAllIndices('123', ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6bc43 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:49.720431 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiMatchAllIndices('123', ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6bc43 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:50.078863 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.080768 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.081188 [ 3731 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.083814 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.100758 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.102636 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.123548 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.125373 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 373.93 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.192192 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.84 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.696411 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 460.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.699857 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 460.32 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.699940 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 2264 entries up to offset 327021: Code: 241. DB::Exception: (total) memory limit exceeded: would use 463.50 MiB (attempt to allocate chunk of 4.18 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.769185 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.17 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:50.774560 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.17 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:51.650539 [ 3728 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 509.19 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (avg_value_size_hint = 54.394287109375, avg_chars_size = 55.673144531249996, limit = 8192): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:51.653641 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 509.19 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (avg_value_size_hint = 54.394287109375, avg_chars_size = 55.673144531249996, limit = 8192): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b6e50 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:51.660417 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 507.64 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/data.bin (position: 131322, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 5eb818f0b924c5aa4793aae7179ce5c782acba000092550300): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:51.663651 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 507.64 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/data.bin (position: 131322, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 5eb818f0b924c5aa4793aae7179ce5c782acba000092550300): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.137925 [ 19621 ] {d503d383-1607-48e6-9a13-b4ec78af0fff} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['12']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 14, line 21) (in query: select multiFuzzyMatchAny('123', 0, ['12']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c5689d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:52.149209 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c5689d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:52.507555 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.23 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.510091 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.23 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.537737 [ 3724 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_163_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.85 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column data): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 3 with max_rows_to_read = 6171): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.550684 [ 3735 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.553295 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.566705 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_163_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.85 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column data): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 3 with max_rows_to_read = 6171): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.608852 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.611239 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.669859 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 16 entries up to offset 2415: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.59 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.681103 [ 18403 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:52.682380 [ 18403 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:53.413041 [ 3724 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.72 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:53.415621 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.72 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:53.429974 [ 19621 ] {5f622abc-3a42-4f18-9aef-1b84eb4b34a4} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['1', '2']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 15, line 22) (in query: select multiFuzzyMatchAny('123', 0, ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c5689d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:53.439474 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAny('123', 0, ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c5689d 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:53.460440 [ 16355 ] {5e682067-8912-466c-889c-8aeb62200cde} executeQuery: Code: 344. DB::Exception: Deduplication in dependent materialized view cannot work together with async inserts. Please disable either `deduplicate_blocks_in_dependent_materialized_views` or `async_insert` setting. (SUPPORT_IS_DISABLED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56698) (comment: 03006_mv_deduplication_throw_if_async_insert.sql) (query 5, line 13) (in query: INSERT INTO 03006_test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1271: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033838fed 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:27:53.470448 [ 16355 ] {} TCPHandler: Code: 344. DB::Exception: Deduplication in dependent materialized view cannot work together with async inserts. Please disable either `deduplicate_blocks_in_dependent_materialized_views` or `async_insert` setting. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1271: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033838fed 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 6. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:27:53.470465 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:53.474204 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.88 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:53.500852 [ 16355 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000116c088a 4. ./build_docker/./src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b1ad9 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0b9e 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x000000003aee7c24 10. ./build_docker/./src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd112 11. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:27:53.502314 [ 16355 ] {} TCPHandler: Code: 101. DB::Exception: Unexpected packet Data received from client. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x000000003aecd753 5. ./build_docker/./src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x000000003aea2b94 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:27:53.574123 [ 3736 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_102_18} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column ProfileEvent_IOUringSQEsResubmitsAsync): (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_1_91_17/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 1093): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:53.576792 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_102_18}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column ProfileEvent_IOUringSQEsResubmitsAsync): (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_1_91_17/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 1093): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:54.124947 [ 17227 ] {69fc0bd1-4bb4-44a2-b734-86b7d0fe3ba6} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 443.65 MiB (attempt to allocate chunk of 8.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading the value of key bbb): While executing JSONEachRowRowInputFormat. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55844) (comment: 00728_json_each_row_parsing.sh) (in query: INSERT INTO json_parse FORMAT JSONEachRow ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48bc9 12. ./src/Common/PODArray.h:428: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7c3c38 13. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 14. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 15. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 16. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 17. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 18. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 19. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 28. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 29. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 30. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 2025.11.13 09:27:54.139766 [ 17227 ] {69fc0bd1-4bb4-44a2-b734-86b7d0fe3ba6} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 443.65 MiB (attempt to allocate chunk of 8.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading the value of key bbb): While executing JSONEachRowRowInputFormat. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48bc9 12. ./src/Common/PODArray.h:428: DB::SerializationString::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000002f7c3c38 13. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:841: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x000000002f6cb69c 14. ./build_docker/./src/Formats/JSONUtils.cpp:295: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000003b0a9e9b 15. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:136: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5de58e 16. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:194: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000003b5ded44 17. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:228: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b5df966 18. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x000000003b38ad5f 19. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003b21fdb9 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 26. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1dd3 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1891: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384368b 28. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 29. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 30. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:54.554964 [ 17376 ] {4a23c860-afcf-4f62-88a6-76932aed715e} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.10 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50706) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_11`.`tMM` AS `__table1` WHERE ((toYYYYMM(`__table1`.`d`) + 1) > 202010) AND (toStartOfDay(`__table1`.`d`) < '2020-10-02 00:00:00')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:27:54.575898 [ 17376 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.10 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:27:54.596702 [ 18403 ] {9f47725b-3ca0-4f92-a731-8334cc43e39a} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Query memory tracker: fault injected. Would use 1.10 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56724) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toYYYYMM(d)+1 > 202010 and toStartOfDay(d) < '2020-10-02 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:54.610082 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 496.71 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:54.613062 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_117_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 496.71 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:54.641374 [ 18403 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Query memory tracker: fault injected. Would use 1.10 MiB (attempt to allocate chunk of 1.10 MiB), maximum: 9.31 GiB. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, String&&, String&&) @ 0x000000001f854587 4. ./build_docker/./src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f851076 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 13. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 14. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 15. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:27:54.697578 [ 5803 ] {fd887cbb-4b6f-4e90-beea-ea10541e8438} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:34882). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34882) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_11`.`tMM` AS `__table1` WHERE ((toYYYYMM(`__table1`.`d`) + 1) > 202010) AND (toStartOfDay(`__table1`.`d`) < '2020-10-02 00:00:00')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:728: DB::TCPHandler::runImpl() @ 0x000000003aea4c36 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:27:54.711041 [ 5803 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:34882). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:728: DB::TCPHandler::runImpl() @ 0x000000003aea4c36 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:27:55.162277 [ 19620 ] {20e98098-a9c1-4d73-8026-934ad6e22553} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt8(1)). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56752) (comment: 00800_function_java_hash_with_unsigined_types.sh) (query 1, line 1) (in query: SELECT javaHash(toUInt8(1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098d14f8 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098cffc9 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x00000000098cefaf 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce50c 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce032 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:27:55.177790 [ 19620 ] {} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt8(1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098d14f8 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098cffc9 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x00000000098cefaf 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce50c 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce032 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:27:55.469080 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.97 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:55.472344 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.97 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.149893 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.90 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.153041 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.90 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.165145 [ 19620 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.166625 [ 19620 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.90 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.246969 [ 19621 ] {bc0fc654-16c7-4ddf-91a4-3e61f6dd03bc} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['12']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 17, line 25) (in query: select multiFuzzyMatchAnyIndex('123', 0, ['12']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c64bc0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:56.363213 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c64bc0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:56.473749 [ 3734 ] {205b8dc2-7b75-4374-9596-7f359671c6d7::202511_1_151_30} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.42 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.483493 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {205b8dc2-7b75-4374-9596-7f359671c6d7::202511_1_151_30}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.42 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.501506 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.503126 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.841746 [ 3738 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_163_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.02 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c11595 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b0f68d 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.846181 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_163_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.02 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<4ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c11595 12. ./build_docker/./src/Columns/ColumnVector.cpp:524: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000037b0f68d 13. ./src/Columns/IColumn.h:210: DB::MergeTreeDataPartWriterCompact::ColumnsBuffer::add(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&&) @ 0x0000000039ba7dbe 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67d4 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 24. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 25. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.881256 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.883476 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.14 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.911713 [ 16355 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.913022 [ 16355 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.914314 [ 3739 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.88 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/event_time_microseconds.bin (position: 39458, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 244fb0ee346db874fbf6806eaa27d49782129a000000000100): (while reading column event_time_microseconds): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationDecimalBase.cpp:63: DB::SerializationDecimalBase::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f5f4be7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 23. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.918199 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.88 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/event_time_microseconds.bin (position: 39458, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 244fb0ee346db874fbf6806eaa27d49782129a000000000100): (while reading column event_time_microseconds): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationDecimalBase.cpp:63: DB::SerializationDecimalBase::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f5f4be7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 23. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.933743 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_118_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.90 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.937491 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_118_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.90 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.949326 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:56.952482 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:57.378144 [ 19621 ] {81114a3f-a971-4361-b0c0-32ed0b4e60cb} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['1', '2']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 18, line 26) (in query: select multiFuzzyMatchAnyIndex('123', 0, ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c64bc0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:57.405136 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAnyIndex('123', 0, ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c64bc0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:27:57.806585 [ 18403 ] {922fcf15-de4e-41ed-9ac2-e86363b01e0b} DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.86 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6272c4 11. ./src/Common/HashTable/HashTable.h:491: HashTable, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator>::alloc(TwoLevelHashTableGrower<8ul> const&) @ 0x0000000033cfee88 12. ./src/Common/HashTable/HashTable.h:703: std::shared_ptr, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> std::allocate_shared[abi:ne190107], HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> const&) @ 0x0000000033cff25e 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type, unsigned long) @ 0x0000000033cf45c3 14. ./base/base/../base/constexpr_helpers.h:24: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x0000000033bc37c6 15. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:251: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbc47a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:ne190107], unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000032845271 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 4. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:57.845376 [ 18403 ] {922fcf15-de4e-41ed-9ac2-e86363b01e0b} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.86 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56812) (comment: 00056_join_number_string.sql) (query 1, line 1) (in query: SELECT left, right FROM ( SELECT number % 4 AS k1, toString(number % 3) AS k2, number AS left FROM system.numbers LIMIT 10 ) js1 ALL LEFT JOIN ( SELECT number % 2 AS k1, toString(number % 6) AS k2, number AS right FROM system.numbers LIMIT 10 ) js2 USING k1, k2 ORDER BY left, right;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6272c4 11. ./src/Common/HashTable/HashTable.h:491: HashTable, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator>::alloc(TwoLevelHashTableGrower<8ul> const&) @ 0x0000000033cfee88 12. ./src/Common/HashTable/HashTable.h:703: std::shared_ptr, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> std::allocate_shared[abi:ne190107], HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> const&) @ 0x0000000033cff25e 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type, unsigned long) @ 0x0000000033cf45c3 14. ./base/base/../base/constexpr_helpers.h:24: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x0000000033bc37c6 15. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:251: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbc47a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:ne190107], unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000032845271 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:27:57.874364 [ 18403 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.86 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6272c4 11. ./src/Common/HashTable/HashTable.h:491: HashTable, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator>::alloc(TwoLevelHashTableGrower<8ul> const&) @ 0x0000000033cfee88 12. ./src/Common/HashTable/HashTable.h:703: std::shared_ptr, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> std::allocate_shared[abi:ne190107], HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>, std::allocator, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>>, 0>(std::allocator, HashMapCell, DB::RowRefList, UInt128TrivialHash, HashTableNoState, PairNoInit, DB::RowRefList>>, UInt128TrivialHash, TwoLevelHashTableGrower<8ul>, Allocator, HashMapTable>> const&) @ 0x0000000033cff25e 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type, unsigned long) @ 0x0000000033cf45c3 14. ./base/base/../base/constexpr_helpers.h:24: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x0000000033bc37c6 15. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:251: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000033bbc47a 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: void std::__function::__policy_invoker::__call_impl[abi:ne190107], unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000032845271 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fac1774 4. ./build_docker/./src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x00000000327fca15 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&, 0>(std::allocator const&, std::shared_ptr&, unsigned long const&, DB::Block const&, DB::StatsCollectingParams&) @ 0x0000000032cf5054 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x0000000032ceb6a9 7. ./build_docker/./src/Processors/QueryPlan/JoinStepLogical.cpp:746: DB::JoinStepLogical::convertToPhysical(DB::JoinActionRef&, bool, unsigned long, unsigned long, String, std::chrono::duration>, DB::ExpressionActionsSettings const&, std::optional) @ 0x000000003c19f2bb 8. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x000000003c4ecc12 9. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000003c4c3e2b 10. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f90b8 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000032bdeda5 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000032bde721 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 15. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 16. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 18. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 21. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:27:58.804094 [ 16355 ] {116ee6f2-4875-49c4-bbf5-f151b3ad30c0} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt32(1)). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56880) (comment: 00800_function_java_hash_with_unsigined_types.sh) (query 1, line 1) (in query: SELECT javaHash(toUInt32(1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098d293b 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098cfe6b 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x00000000098cefaf 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce50c 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce032 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:27:58.860579 [ 3739 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.43 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:58.862470 [ 18391 ] {e7655f86-0e57-4d3a-9daf-af4b49c1b11b} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 411.46 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46630) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_11`.`tMM` AS `__table1` WHERE (toYYYYMM(`__table1`.`d` - 1) + 1) = 202010), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:58.865058 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.43 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:58.891626 [ 16355 ] {} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt32(1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098d293b 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098cfe6b 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x00000000098cefaf 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce50c 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce032 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:27:58.933562 [ 3725 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_163_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.42 MiB (attempt to allocate chunk of 1.11 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:58.937946 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_163_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.42 MiB (attempt to allocate chunk of 1.11 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:58.941941 [ 16691 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 404.35 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:58.943989 [ 16691 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 404.35 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:58.943954 [ 18391 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 411.46 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:27:58.992849 [ 3736 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:59.017915 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:27:59.299633 [ 19620 ] {898a7e4e-67e2-4ac1-8a2c-c4f25ebd91b7} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: (total) memory limit exceeded: would use 411.46 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56904) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toYYYYMM(d-1)+1 = 202010;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:27:59.596853 [ 19620 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: (total) memory limit exceeded: would use 411.46 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:00.112749 [ 19621 ] {347c4042-fcef-43ef-ba56-244c70bc221f} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['12']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 20, line 29) (in query: select multiFuzzyMatchAllIndices('123', 0, ['12']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c424a0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:28:00.128830 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['12']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c424a0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:28:00.398107 [ 3739 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 421.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:00.403319 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 421.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:00.545242 [ 3732 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:00.552163 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:00.826507 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_118_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.62 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:00.830748 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_118_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.62 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:00.857317 [ 17390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.62 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:01.361169 [ 17390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:01.375672 [ 3725 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.01 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:01.379187 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 409.01 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:01.514827 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.65 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:01.783514 [ 19621 ] {9361cbfc-0b1c-4e1e-9908-964f64a4f4c8} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['1', '2']). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 21, line 30) (in query: select multiFuzzyMatchAllIndices('123', 0, ['1', '2']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c424a0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:28:01.803085 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): In scope SELECT multiFuzzyMatchAllIndices('123', 0, ['1', '2']). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c424a0 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:28:01.957442 [ 16198 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.49 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:01.959873 [ 16198 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.49 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.021048 [ 16198 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.49 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.024316 [ 16198 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.49 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 13. ./src/IO/WriteBuffer.h:183: std::shared_ptr> std::make_shared[abi:ne190107], Poco::Net::StreamSocket&, StrongTypedef&, 0>(Poco::Net::StreamSocket&, StrongTypedef&) @ 0x000000003af1318f 14. ./build_docker/./src/Server/TCPHandler.cpp:334: DB::TCPHandler::runImpl() @ 0x000000003aea0ea3 15. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.119724 [ 3729 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_173_47} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.126543 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_173_47}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.341375 [ 16198 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.345222 [ 16198 ] {} DynamicQueryHandler: Cannot send exception to client: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./build_docker/./src/Server/HTTPHandler.cpp:623: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace72e6 14. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.346527 [ 3733 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.01 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.352676 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 402.01 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.362207 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.94 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.619257 [ 15982 ] {3f01448d-62d6-4332-bbd8-899283f3e8aa} executeQuery: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt64(1)). (NOT_IMPLEMENTED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58602) (comment: 00800_function_java_hash_with_unsigined_types.sh) (query 1, line 1) (in query: SELECT javaHash(toUInt64(1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098d335b 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098cffe2 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x00000000098cefaf 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce50c 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce032 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:28:02.674031 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.03 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.678316 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.03 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:02.722079 [ 15982 ] {} TCPHandler: Code: 48. DB::Exception: Unsigned types are not supported: In scope SELECT javaHash(toUInt64(1)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. void DB::TargetSpecific::Default::FunctionAnyHash::executeIntType(char const&, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098d335b 5. void DB::TargetSpecific::Default::FunctionAnyHash::executeAny(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&) const @ 0x00000000098cffe2 6. DB::TargetSpecific::Default::FunctionAnyHash::executeForArgument(char const&, DB::IDataType const*, DB::IColumn const*, DB::PODArray, 63ul, 64ul>&, bool&) const @ 0x00000000098cefaf 7. DB::TargetSpecific::Default::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce50c 8. DB::ImplementationSelector::selectAndExecute(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000091bfd83 9. DB::FunctionAnyHash::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000098ce032 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 11. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 2025.11.13 09:28:02.796886 [ 16691 ] {1ba81d37-0dc4-4c25-baca-d7fa7fc80a09} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56998) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toYYYYMM(d-1)+1 = 202010;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 13. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 14. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 15. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac820b 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa75bc6 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003aa90dc2 18. ./build_docker/./src/Client/ConnectionPool.cpp:103: DB::ConnectionPool::get(DB::ConnectionTimeouts const&, DB::Settings const&, bool) @ 0x000000003aaf0e2c 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:51: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadb565 20. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:108: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107], String const&, DB::Block const&, std::shared_ptr, std::shared_ptr, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::shared_ptr)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f28b236 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 22. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 23. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 24. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 25. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:28:02.959974 [ 16691 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.96 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 13. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 14. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:25: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac829c 15. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:21: DB::WriteBufferFromPocoSocketChunked::WriteBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac820b 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa75bc6 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003aa90dc2 18. ./build_docker/./src/Client/ConnectionPool.cpp:103: DB::ConnectionPool::get(DB::ConnectionTimeouts const&, DB::Settings const&, bool) @ 0x000000003aaf0e2c 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:51: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadb565 20. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:108: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107], String const&, DB::Block const&, std::shared_ptr, std::shared_ptr, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::shared_ptr)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f28b236 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 22. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 23. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 24. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 25. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:03.105004 [ 3737 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_163_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.43 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.49 GiB, maximum: 15.30 GiB.: (while reading column address): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 9167): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<16ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008e410b7 12. ./build_docker/./src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:181: DB::SerializationIP::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f652f9f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:03.115922 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_163_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.43 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.49 GiB, maximum: 15.30 GiB.: (while reading column address): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 9167): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<16ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008e410b7 12. ./build_docker/./src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:181: DB::SerializationIP::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f652f9f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:03.906476 [ 3726 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.87 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:03.910254 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.87 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:04.026449 [ 4017 ] {a5d1ad8d-22d6-4d48-bd61-9e885539b563} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.57 MiB (attempt to allocate chunk of 1.38 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while converting source column `modulo(number, 10000.)` to destination column key: while executing 'FUNCTION _CAST(modulo(number, 10000.) :: 0, String :: 1) -> _CAST(modulo(number, 10000.), String) String : 2'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56962) (comment: 01513_optimize_aggregation_in_order_memory_long.sql) (query 3, line 6) (in query: -- 10e3 groups, 1e3 keys each insert into data_01513 select number%10e3 from numbers(2e6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./src/Functions/FunctionsConversion.h:1533: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ce004fb 13. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde8a79 14. ./src/Core/callOnTypeIndex.h:268: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7e3b 15. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 21. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 22. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 27. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 28. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 29. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:28:04.105398 [ 4017 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.57 MiB (attempt to allocate chunk of 1.38 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while converting source column `modulo(number, 10000.)` to destination column key: while executing 'FUNCTION _CAST(modulo(number, 10000.) :: 0, String :: 1) -> _CAST(modulo(number, 10000.), String) String : 2'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./src/Functions/FunctionsConversion.h:1533: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002ce004fb 13. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde8a79 14. ./src/Core/callOnTypeIndex.h:268: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7e3b 15. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 16. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 17. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 18. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 19. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 20. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 21. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 22. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 23. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 24. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 25. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 26. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 27. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 28. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 29. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:28:04.268146 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.91 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:04.344564 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.91 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:04.900432 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_118_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:04.905153 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_118_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:04.916988 [ 19621 ] {e3e8f5ae-bc6b-4981-92f8-90728a93e57a} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 2'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 24, line 35) (in query: select multiMatchAny(materialize('123'), materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107d11d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:04.971669 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107d11d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:05.432735 [ 3733 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 412.72 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:05.440047 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_76_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 412.72 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:05.464584 [ 16141 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:05.467664 [ 16141 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:05.496325 [ 3736 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 412.70 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:05.504888 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 412.70 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:05.524119 [ 5803 ] {376b9555-bf57-4fb2-88da-00a94c94651c} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.45 MiB (attempt to allocate chunk of 1.32 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58646) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toStartOfMonth(d) >= '2020-09-15';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003aa90dc2 18. ./build_docker/./src/Client/ConnectionPool.cpp:103: DB::ConnectionPool::get(DB::ConnectionTimeouts const&, DB::Settings const&, bool) @ 0x000000003aaf0e2c 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:51: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadb565 20. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:108: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107], String const&, DB::Block const&, std::shared_ptr, std::shared_ptr, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::shared_ptr)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f28b236 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 22. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 23. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 24. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 25. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:28:05.546200 [ 16141 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:05.553723 [ 16141 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:05.616750 [ 5803 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.45 MiB (attempt to allocate chunk of 1.32 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::Connection::forceConnected(DB::ConnectionTimeouts const&) @ 0x000000003aa90dc2 18. ./build_docker/./src/Client/ConnectionPool.cpp:103: DB::ConnectionPool::get(DB::ConnectionTimeouts const&, DB::Settings const&, bool) @ 0x000000003aaf0e2c 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:51: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadb565 20. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:108: std::unique_ptr> std::__function::__policy_invoker> (std::function)>::__call_impl[abi:ne190107], String const&, DB::Block const&, std::shared_ptr, std::shared_ptr, std::map, std::allocator>> const&, std::map, std::less, std::allocator>>> const&, DB::QueryProcessingStage::Enum, std::optional, std::shared_ptr)::$_0, std::unique_ptr> (std::function)>>(std::__function::__policy_storage const*, std::function&&) @ 0x000000002f28b236 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f276e80 22. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 23. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 24. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 25. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:05.672565 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 795 entries up to offset 498863: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.51 MiB (attempt to allocate chunk of 4.33 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 10. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 11. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 12. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 13. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 14. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 15. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 27. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 28. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x000000003335e7be 29. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba3381 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba31bf 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:05.889830 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 1981 entries up to offset 330983: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.29 MiB (attempt to allocate chunk of 4.16 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:06.099970 [ 16693 ] {c870b656-cb51-4b53-98ba-9fca72d99c92} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.54 MiB (attempt to allocate chunk of 1.38 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58688) (comment: 02887_tuple_element_distributed.sql) (query 1, line 1) (in query: SELECT equals(tupleElement(tuple('a', 10) AS x, 1), 'a') FROM remote('127.0.0.{1,2,3}', numbers(2));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9c535 14. ./build_docker/./src/Client/Connection.cpp:1060: DB::Connection::sendScalarsData(std::map, std::allocator>>&) @ 0x000000003aa9f1e4 15. ./build_docker/./src/Client/HedgedConnections.cpp:108: DB::HedgedConnections::sendScalarsData(std::map, std::allocator>>&) @ 0x000000003ab2e580 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:866: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278240 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 18. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 19. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 20. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:28:06.121274 [ 15982 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33896, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:06.123245 [ 15982 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33896, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001fcaac4f 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001fcabbe1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aac5eba 6. DB::ReadBuffer::next() @ 0x0000000008ef7cef 7. ./src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x000000003aea29f3 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:06.217554 [ 16887 ] {3b1de351-fda6-44f4-9d0e-e4a7a79de342} TCPHandler: Can't send logs or exception to client. Close connection.: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:55722). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::sendEndOfStream(DB::QueryState&) @ 0x000000003aed6396 7. ./build_docker/./src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x000000003aea569c 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:06.219895 [ 16693 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.54 MiB (attempt to allocate chunk of 1.38 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::Connection::sendData(DB::Block const&, String const&, bool) @ 0x000000003aa9c535 14. ./build_docker/./src/Client/Connection.cpp:1060: DB::Connection::sendScalarsData(std::map, std::allocator>>&) @ 0x000000003aa9f1e4 15. ./build_docker/./src/Client/HedgedConnections.cpp:108: DB::HedgedConnections::sendScalarsData(std::map, std::allocator>>&) @ 0x000000003ab2e580 16. ./build_docker/./src/QueryPipeline/RemoteQueryExecutor.cpp:866: DB::RemoteQueryExecutor::sendQueryUnlocked(DB::ClientInfo::QueryKind, std::function) @ 0x000000002f278240 17. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:48: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea0be 18. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 19. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 20. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:06.963715 [ 3730 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.89 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:06.968894 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.89 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:07.021091 [ 16141 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:07.027214 [ 16141 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.01 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:07.312622 [ 19621 ] {92875407-7cd4-41bf-8fa5-2923a46c20d0} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 2'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 25, line 36) (in query: select multiMatchAny(materialize('123'), materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107d11d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:07.346123 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAny(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAny(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000003107d11d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:07.740420 [ 3736 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_164_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.21 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column children): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 3 with max_rows_to_read = 6171): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:07.749332 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_164_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.21 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column children): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 3 with max_rows_to_read = 6171): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:07.830373 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:07.836179 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 450.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:08.229056 [ 3727 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.70 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:08.232416 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.70 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:08.769921 [ 3733 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_118_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:08.774288 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_118_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:08.963048 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:08.965168 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:09.011112 [ 3730 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.66 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:09.014685 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.66 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:09.282497 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.68 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:09.289925 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.68 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:09.388758 [ 16693 ] {79aa0bb3-1587-4597-af2b-88cc09a4c63c} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58760) (comment: 00616_final_single_part.sql) (query 8, line 17) (in query: CREATE TABLE replacing_00616 ENGINE = ReplacingMergeTree(date, x, 4096, ver) AS SELECT * FROM test_00616;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:28:09.406830 [ 19621 ] {b0c526fd-e114-4047-abc2-294f3a0ab5d0} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 2'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 27, line 39) (in query: select multiMatchAnyIndex(materialize('123'), materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c78c0e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:09.431463 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c78c0e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:09.645772 [ 16693 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.67 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:28:09.912766 [ 3729 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_165_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.69 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/data.bin (position: 47623, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 72a731af7bb4d561fc4ef5a6f61268438232020000e0150200): (while reading column address): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 14. ./build_docker/./src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:182: DB::SerializationIP::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f652fca 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:09.916341 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_165_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.69 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/data.bin (position: 47623, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 72a731af7bb4d561fc4ef5a6f61268438232020000e0150200): (while reading column address): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 14. ./build_docker/./src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:182: DB::SerializationIP::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f652fca 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:10.102684 [ 17752 ] {b7c3d65a-9f3a-41a7-a5a8-4fefcbfaa51e} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 405.39 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.27 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58782) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toStartOfMonth(d) >= '2020-09-01';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:28:10.177947 [ 3728 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.46 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:10.188444 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.46 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:10.237813 [ 17752 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 405.39 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.27 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:10.355896 [ 3915 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::SessionLogElement]: Failed to flush system log system.session_log with 911 entries up to offset 21746: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.98 MiB (attempt to allocate chunk of 4.31 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033305e41 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:11.437403 [ 19621 ] {ae08a139-89a0-45ac-a029-adc0a04885a1} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 2'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 28, line 40) (in query: select multiMatchAnyIndex(materialize('123'), materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c78c0e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:11.569223 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAnyIndex(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAnyIndex(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c78c0e 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:11.765447 [ 3727 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 469.20 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:11.770623 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 469.20 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:11.819613 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 469.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:11.828645 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_118_3} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.82 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:11.831590 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_83_118_3}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.82 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:11.862252 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 469.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.296591 [ 15982 ] {f0b6ca24-fed3-4746-9202-330e83edcee5} executeQuery: Code: 57. DB::Exception: Table test_9.aine already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48888) (comment: 01073_attach_if_not_exists.sql) (query 2, line 3) (in query: ATTACH TABLE aine;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:28:12.321118 [ 15982 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.aine already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:28:12.496849 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.499201 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.523496 [ 17383 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.527057 [ 17383 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.595880 [ 18728 ] {3d797ab6-a7e5-454e-939e-6eb02b93a89a} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.81 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55304) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_11`.`tMM` AS `__table1` WHERE toStartOfMonth(`__table1`.`d`) >= '2020-09-01'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:12.629614 [ 3732 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.84 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.633132 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.84 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.693226 [ 3725 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_104_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.82 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.736824 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_104_15}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.82 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.760690 [ 18728 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.81 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:12.766566 [ 19499 ] {28140254-7c07-413e-96f1-3f2eb682fc7e} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58768) (comment: 00814_replicated_minimalistic_part_header_zookeeper.sh) (query 11, line 32) (in query: INSERT INTO part_header_r2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:373: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a3c209c 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:28:12.840710 [ 16693 ] {745eae2c-2c4f-4ba5-9d57-79aab20dd4a4} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 399.81 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48870) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: select uniqExact(_part), count() from tMM where toStartOfMonth(d) >= '2020-09-01';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:28:12.859932 [ 19499 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.26 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:373: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000003a3c209c 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:28:12.882182 [ 3737 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_165_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.37 MiB (attempt to allocate chunk of 1.13 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column data): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 9167): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.886129 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_165_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.37 MiB (attempt to allocate chunk of 1.13 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB.: (while reading column data): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 9167): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:12.927058 [ 16693 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 399.81 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:12.951986 [ 16141 ] {84c3404b-0207-4267-bfb4-6c384bd28dce} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:39612). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39612) (comment: 01508_partition_pruning_long_1.sh) (query 1, line 1) (in query: SELECT uniqExact(`__table1`.`_part`) AS `uniqExact(_part)`, count() AS `count()` FROM `test_11`.`tMM` AS `__table1` WHERE toStartOfMonth(`__table1`.`d`) >= '2020-09-01'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:728: DB::TCPHandler::runImpl() @ 0x000000003aea4c36 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:28:12.980096 [ 16141 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:39612). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2532: DB::TCPHandler::sendLogData(DB::QueryState&, DB::Block const&) @ 0x000000003af0c041 7. ./build_docker/./src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x000000003aed5bf8 8. ./build_docker/./src/Server/TCPHandler.cpp:728: DB::TCPHandler::runImpl() @ 0x000000003aea4c36 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:28:13.726424 [ 17752 ] {7fe71001-768b-499b-af0e-3d1932de9fbd} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test' in scope SELECT x, y FROM test. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48924) (comment: 01599_mutation_query_params.sh) (query 1, line 1) (in query: SELECT x, y FROM test), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:28:13.811139 [ 19621 ] {3078b4f5-1485-4adb-a094-54de1d6daed0} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 2'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 30, line 43) (in query: select multiMatchAllIndices(materialize('123'), materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6bc43 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:13.858274 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.71 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:13.861711 [ 17752 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test' in scope SELECT x, y FROM test. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 17. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 19. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 22. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 23. ? @ 0x00007fa150622ac3 24. ? @ 0x00007fa1506b4850 2025.11.13 09:28:13.870931 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6bc43 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:13.924021 [ 3737 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_176_35} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.81 MiB (attempt to allocate chunk of 1.09 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:13.927666 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_176_35}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 451.81 MiB (attempt to allocate chunk of 1.09 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:13.964680 [ 16198 ] {381aa9f4-70b1-4928-84a7-4b08c6da43d4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:40068) (comment: 00814_replicated_minimalistic_part_header_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_rifymv1x SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:28:13.989357 [ 16198 ] {381aa9f4-70b1-4928-84a7-4b08c6da43d4} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:14.146713 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.79 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:14.160671 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.79 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:14.224600 [ 3735 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.61 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:14.228812 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.61 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:14.254010 [ 3731 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_165_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.60 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:14.257430 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_165_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.60 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:14.995689 [ 3739 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_165_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.11 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/data.bin (position: 47623, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 72a731af7bb4d561fc4ef5a6f61268438232020000e0150200): (while reading column address): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 14. ./build_docker/./src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:182: DB::SerializationIP::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f652fca 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:14.999053 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_165_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.11 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/data.bin (position: 47623, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 72a731af7bb4d561fc4ef5a6f61268438232020000e0150200): (while reading column address): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 14. ./build_docker/./src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:182: DB::SerializationIP::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f652fca 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.046399 [ 3736 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_176_35} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.53 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.051490 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_176_35}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.53 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.102929 [ 18392 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.104616 [ 3724 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_103_18} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.55 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: (while reading column CurrentMetric_HTTPConnection): (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_1_91_17/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 1093): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6f81ff 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.105984 [ 18392 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.109016 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_1_103_18}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.55 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: (while reading column CurrentMetric_HTTPConnection): (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_1_91_17/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 1093): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6f81ff 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.371881 [ 19621 ] {14d3dac7-06ca-4f78-b291-020288ecc4c9} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 2'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 31, line 44) (in query: select multiMatchAllIndices(materialize('123'), materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6bc43 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:15.402789 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiMatchAllIndices(materialize('123'_String) :: 3, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiMatchAllIndices(materialize('123'_String), materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 2'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c6bc43 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:15.430803 [ 15982 ] {8a3ab6cd-a17f-42d3-934e-56e4792c211f} executeQuery: Code: 60. DB::Exception: Could not find table: test. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48970) (comment: 01599_mutation_query_params.sh) (query 1, line 2) (in query: ALTER TABLE test (UPDATE x = _CAST(1, 'UInt32') WHERE y = _CAST(1, 'UInt32'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:28:15.450720 [ 15982 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: test. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000008c5efea 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000329943ba 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 8. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 9. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 11. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 14. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 15. ? @ 0x00007fa150622ac3 16. ? @ 0x00007fa1506b4850 2025.11.13 09:28:15.488689 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_119_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.59 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.493501 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_119_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 413.59 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.496734 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 405.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.499607 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 405.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.537764 [ 18392 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:15.539812 [ 18392 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:16.387211 [ 3892 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::ErrorLogElement]: Failed to flush system log system.error_log with 17 entries up to offset 2466: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.56 MiB (attempt to allocate chunk of 4.14 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033420821 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:16.520703 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:16.522446 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.39 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:16.670083 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:16.671842 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:16.753252 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:16.754735 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.138123 [ 16047 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.140048 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.335232 [ 3737 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_165_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.04 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.337981 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_165_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.04 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.364156 [ 3736 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_176_35} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.23 MiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column LatencyEvent_DiskS3FirstByteReadAttempt1Microseconds): (while reading from part /var/lib/clickhouse/store/1ec/1ec8b98a-4739-4044-a897-d4d41f41f429/202511_1_171_34/ in table system.latency_log (1ec8b98a-4739-4044-a897-d4d41f41f429) located on disk default of type local, from mark 0 with max_rows_to_read = 1270): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.366704 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_176_35}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.23 MiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column LatencyEvent_DiskS3FirstByteReadAttempt1Microseconds): (while reading from part /var/lib/clickhouse/store/1ec/1ec8b98a-4739-4044-a897-d4d41f41f429/202511_1_171_34/ in table system.latency_log (1ec8b98a-4739-4044-a897-d4d41f41f429) located on disk default of type local, from mark 0 with max_rows_to_read = 1270): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.368546 [ 3728 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.10 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.370763 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 417.10 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.395237 [ 16047 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.28 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.397329 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.28 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.541681 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.614178 [ 16047 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.98 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.615980 [ 19621 ] {c7c49281-4ce2-4196-a15e-adb39d7fe8d8} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 33, line 47) (in query: select multiFuzzyMatchAny(materialize('123'), 0, materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c5689d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:17.617919 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.98 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.634787 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c5689d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:17.636540 [ 2997 ] {42b03b38-9558-4d77-bf0f-72dc96f63992} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.98 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49040) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 1) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_replicated_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:17.699583 [ 2997 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 380.98 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:17.727290 [ 17383 ] {f81c049d-225f-4b80-8120-219a61c0b42a} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.94 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48946) (comment: 03368_bfloat16_merge_join.sql) (query 4, line 4) (in query: INSERT INTO TABLE t0 (c0, c1) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:28:17.754366 [ 17383 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.94 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:28:17.785451 [ 16047 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.787099 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:17.914308 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:18.269674 [ 19499 ] {} DynamicQueryHandler: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000002e6b4aed 4. ./build_docker/./src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b2729 5. ./build_docker/./src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000002e6b02a9 6. ./build_docker/./src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000002e6b0a5c 7. ./build_docker/./src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ec64e 8. ./build_docker/./src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000317ed7b0 9. ./build_docker/./src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acde19b 10. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 13. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 16. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:18.635225 [ 16047 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 453.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:18.711789 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 469.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:18.716030 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 469.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:18.769230 [ 19621 ] {0d7fa224-644d-42ac-a3ce-3bed5c623adf} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 34, line 48) (in query: select multiFuzzyMatchAny(materialize('123'), 0, materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c5689d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:18.784980 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAny(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAny(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt8 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c5689d 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:19.065007 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 423.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.065001 [ 17268 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.073769 [ 17268 ] {} DynamicQueryHandler: Cannot send exception to client: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.95 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./build_docker/./src/Server/HTTPHandler.cpp:623: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000003ace72e6 14. ./build_docker/./src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceeb18 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.092604 [ 3738 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_166_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.23 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_166_166_0/data.bin (position: 29049, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: c89e6102692fc23d21b34d4c591a618182a51d0000f6980200): (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_166_166_0/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 1678): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.095167 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_166_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.23 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_166_166_0/data.bin (position: 29049, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: c89e6102692fc23d21b34d4c591a618182a51d0000f6980200): (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_166_166_0/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 1678): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.102703 [ 3734 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 421.59 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.105100 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 421.59 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.204309 [ 19499 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.205735 [ 19499 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.230790 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_119_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.43 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.233549 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_119_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.43 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.265848 [ 3730 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_176_35} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.52 MiB (attempt to allocate chunk of 1.09 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.269190 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_176_35}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.52 MiB (attempt to allocate chunk of 1.09 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.281093 [ 3731 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.283846 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.427706 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.36 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:19.430727 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.36 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.023333 [ 3736 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_176_35} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.80 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading column LatencyEvent_S3FirstByteReadAttempt2Microseconds): (while reading from part /var/lib/clickhouse/store/1ec/1ec8b98a-4739-4044-a897-d4d41f41f429/202511_1_171_34/ in table system.latency_log (1ec8b98a-4739-4044-a897-d4d41f41f429) located on disk default of type local, from mark 0 with max_rows_to_read = 1270): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.025930 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_176_35}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.80 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading column LatencyEvent_S3FirstByteReadAttempt2Microseconds): (while reading from part /var/lib/clickhouse/store/1ec/1ec8b98a-4739-4044-a897-d4d41f41f429/202511_1_171_34/ in table system.latency_log (1ec8b98a-4739-4044-a897-d4d41f41f429) located on disk default of type local, from mark 0 with max_rows_to_read = 1270): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e763f 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.050957 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.02 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.053506 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.02 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.096664 [ 3738 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.099544 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.78 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.127984 [ 3726 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_166_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.99 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/data.bin (position: 47623, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 72a731af7bb4d561fc4ef5a6f61268438232020000e0150200): (while reading column address): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 14. ./build_docker/./src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:182: DB::SerializationIP::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f652fca 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.130365 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_166_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 386.99 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/data.bin (position: 47623, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 72a731af7bb4d561fc4ef5a6f61268438232020000e0150200): (while reading column address): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 14. ./build_docker/./src/DataTypes/Serializations/SerializationIPv4andIPv6.cpp:182: DB::SerializationIP::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f652fca 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.167717 [ 2997 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.169020 [ 2997 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.249587 [ 2997 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.250922 [ 2997 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.472242 [ 3737 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.474800 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.82 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.526952 [ 18392 ] {0a51cf9a-bd3b-41f1-b70f-a797068096c4} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.71 MiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49048) (comment: 00931_low_cardinality_read_with_empty_array.sql) (query 3, line 9) (in query: INSERT INTO lc_00931 SELECT number, if (number < 10000 OR number > 100000, [toString(number)], emptyArrayString()) FROM system.numbers LIMIT 200000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/Columns/ColumnString.cpp:368: COW::immutable_ptr DB::ColumnString::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x000000003770a894 13. ./src/Columns/ColumnsCommon.h:121: COW::immutable_ptr DB::selectIndexImpl(DB::ColumnString const&, DB::IColumn const&, unsigned long) @ 0x00000000376f23ff 14. ./build_docker/./src/Columns/ColumnString.cpp:348: DB::ColumnString::index(DB::IColumn const&, unsigned long) const @ 0x00000000376e35ee 15. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:217: DB::ColumnLowCardinality::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003752d029 16. ./src/Columns/IColumn.h:210: DB::ColumnArray::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000370a3487 17. ./src/Columns/IColumn.h:210: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec31d 18. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 19. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 23. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:20.569135 [ 16215 ] {66d840a6-1446-4c96-8c69-e79a5e57dd01} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.81 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:49136) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 1) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_replicated_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:20.571079 [ 2997 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.574374 [ 2997 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.578418 [ 3728 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_177_35} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.15 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.572599 [ 18392 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 429.71 MiB (attempt to allocate chunk of 1.20 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c198bc 12. ./build_docker/./src/Columns/ColumnString.cpp:368: COW::immutable_ptr DB::ColumnString::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x000000003770a894 13. ./src/Columns/ColumnsCommon.h:121: COW::immutable_ptr DB::selectIndexImpl(DB::ColumnString const&, DB::IColumn const&, unsigned long) @ 0x00000000376f23ff 14. ./build_docker/./src/Columns/ColumnString.cpp:348: DB::ColumnString::index(DB::IColumn const&, unsigned long) const @ 0x00000000376e35ee 15. ./build_docker/./src/Columns/ColumnLowCardinality.cpp:217: DB::ColumnLowCardinality::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x000000003752d029 16. ./src/Columns/IColumn.h:210: DB::ColumnArray::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x00000000370a3487 17. ./src/Columns/IColumn.h:210: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000330ec31d 18. ./build_docker/./src/Interpreters/Squashing.cpp:45: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000330e9f10 19. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000032aeefeb 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 23. ./src/Processors/Transforms/ApplySquashingTransform.h:29: DB::ApplySquashingTransform::work() @ 0x0000000032aee92e 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:28:20.572763 [ 16141 ] {f2104772-cb2e-4e16-b622-a3bfa2b1a1a8} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.82 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:48938) (comment: 03008_optimize_equal_ranges.sql) (query 12, line 16) (in query: SELECT a, uniqExact(b) FROM t_optimize_equal_ranges GROUP BY a ORDER BY a SETTINGS max_threads = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:28:20.581261 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_177_35}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.15 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.614476 [ 16215 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.81 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:20.629794 [ 16141 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 382.82 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:20.637245 [ 2997 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.638602 [ 2997 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.645628 [ 3919 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::AsynchronousMetricLogElement]: Failed to flush system log system.asynchronous_metric_log with 2264 entries up to offset 335511: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.29 MiB (attempt to allocate chunk of 4.17 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332864ec (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:20.856540 [ 19621 ] {46ccf500-a04f-457e-bcfb-bd444bee5102} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 36, line 51) (in query: select multiFuzzyMatchAnyIndex(materialize('123'), 0, materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c64bc0 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:20.877826 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c64bc0 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:21.458456 [ 9837 ] {} ExternalDictionariesLoader: Could not load external dictionary '1119b8f4-92d2-4582-bb09-e8200cde5e0e', next update is scheduled at 2025-11-13 09:29:07: Code: 60. DB::Exception: Unknown table expression identifier 'test_9hufdy9z.dict_data' in scope SELECT key, v0, v1, v2, v3, v4 FROM test_9hufdy9z.dict_data. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000002702efa8 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x000000002702e915 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0a87 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.513639 [ 3729 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_177_35} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.13 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.516593 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_177_35}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.13 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.530696 [ 3736 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_166_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 466.02 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column children): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.533222 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_166_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 466.02 MiB (attempt to allocate chunk of 1.04 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column children): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 8542): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c19855 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:196: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x000000002f5ac861 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:369: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0352 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 20. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 21. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 30. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.540675 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 476.27 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.543112 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 476.27 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.610404 [ 3726 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.45 MiB (attempt to allocate chunk of 1.46 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_74_74_0/data.bin (position: 65505, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 48fa54b8325afe91b28909b63203d8cf82006f000028a70c00): (while reading column trace): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_74_74_0/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 2850): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b006e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.612912 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 458.45 MiB (attempt to allocate chunk of 1.46 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_74_74_0/data.bin (position: 65505, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 48fa54b8325afe91b28909b63203d8cf82006f000028a70c00): (while reading column trace): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_74_74_0/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 2850): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b006e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.658877 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.660386 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.13 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.663781 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_119_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.43 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.664148 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1102 entries up to offset 501972: Code: 241. DB::Exception: (total) memory limit exceeded: would use 460.48 MiB (attempt to allocate chunk of 4.35 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.667037 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_119_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.43 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.691199 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.692844 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.43 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.727884 [ 16215 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:21.729462 [ 16215 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.91 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:22.672063 [ 3733 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.43 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_148_33/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 0 with max_rows_to_read = 8230): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 14. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 15. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 16. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 23. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:22.688217 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.43 MiB (attempt to allocate chunk of 1.30 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_148_33/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 0 with max_rows_to_read = 8230): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 14. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 15. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 16. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 23. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:22.745086 [ 19621 ] {eebe46df-77d4-44ea-975c-6e14f15040e5} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 37, line 52) (in query: select multiFuzzyMatchAnyIndex(materialize('123'), 0, materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c64bc0 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:22.765610 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAnyIndex(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAnyIndex(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) UInt64 : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c64bc0 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:22.775893 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:22.778765 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.85 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:22.812620 [ 3738 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.37 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:22.815851 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 433.37 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:22.887113 [ 3736 ] {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_104_15} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_1_88_14/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 1526): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:22.889797 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3433295d-eb49-4d85-bc77-2df1069ce0c1::202511_1_104_15}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.75 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/343/3433295d-eb49-4d85-bc77-2df1069ce0c1/202511_1_88_14/ in table system.query_metric_log (3433295d-eb49-4d85-bc77-2df1069ce0c1) located on disk default of type local, from mark 0 with max_rows_to_read = 1526): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:22.944188 [ 3726 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_166_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:22.946713 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_166_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.69 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 20. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 21. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 22. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:23.076409 [ 16203 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:23.077787 [ 16203 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:23.107899 [ 17385 ] {278d0d68-84e0-4bab-827d-bc2f211fd18a} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.92 MiB (attempt to allocate chunk of 1.33 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36862) (comment: 00228_shard_quantiles_deterministic_merge_overflow.sql) (query 2, line 4) (in query: -- test merge does not cause overflow select ignore(quantilesDeterministic(0.5, 0.9)(number, number)) from (select number from remote('127.0.0.{2,3}', system, numbers) limit 1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 18. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:28:23.117603 [ 16203 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:23.118945 [ 16203 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:23.154457 [ 3727 ] {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_177_35} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.70 MiB (attempt to allocate chunk of 1.11 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:23.156974 [ 17385 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.92 MiB (attempt to allocate chunk of 1.33 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 13. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 14. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 15. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:15: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, unsigned long) @ 0x000000003aac24cb 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x000000003aa755d1 17. ./build_docker/./src/Client/Connection.cpp:634: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x000000003aa8fef3 18. ./build_docker/./src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x000000003aadbba7 19. ./build_docker/./src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x000000003aae1f80 20. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 21. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 22. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:28:23.157477 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1ec8b98a-4739-4044-a897-d4d41f41f429::202511_1_177_35}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.70 MiB (attempt to allocate chunk of 1.11 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037b174e1 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8ac62 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:23.865540 [ 3732 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:23.868148 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:23.911308 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_119_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 428.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:23.913939 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_119_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 428.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:24.138125 [ 3727 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 422.40 MiB (attempt to allocate chunk of 1.24 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:24.140632 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 422.40 MiB (attempt to allocate chunk of 1.24 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Columns/ColumnTuple.cpp:677: DB::ColumnTuple::shrinkToFit() @ 0x0000000037780edf 13. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 14. ./build_docker/./src/Columns/ColumnMap.cpp:300: DB::ColumnMap::shrinkToFit() @ 0x00000000375e83b1 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 16. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 17. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 22. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 24. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 26. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:24.148844 [ 16344 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.66 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:24.150450 [ 16344 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 416.66 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:24.187451 [ 16215 ] {9176d1d3-1b0d-45cd-b0d9-355aeb284c23} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36844) (comment: 01490_nullable_string_to_enum.sql) (query 6, line 8) (in query: INSERT INTO t_enum(x) SELECT x from t_source WHERE x in ('hello', 'world');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Storages/StorageLog.cpp:365: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x0000000038f69119 18. ./contrib/llvm-project/libcxx/include/__utility/pair.h:478: std::unique_ptr, void*>, std::__tree_node_destructor, void*>>>> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__construct_node, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x0000000038f68c08 19. ./contrib/llvm-project/libcxx/include/__tree:1779: std::pair, std::__tree_node, void*>*, long>>, bool> std::map, std::allocator>>::try_emplace[abi:ne190107] const&, String const&, unsigned long, std::shared_ptr&, unsigned long const&>(String const&, std::shared_ptr const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&) @ 0x0000000038f67d83 20. ./build_docker/./src/Storages/StorageLog.cpp:500: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000038f5a1c3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 23. ./build_docker/./src/Storages/StorageLog.cpp:487: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x0000000038f3cb45 24. ./build_docker/./src/Storages/StorageLog.cpp:420: DB::LogSink::consume(DB::Chunk&) @ 0x0000000038f3c493 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 2025.11.13 09:28:24.271096 [ 16215 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./build_docker/./src/Storages/StorageLog.cpp:365: DB::LogSink::Stream::Stream(std::shared_ptr const&, String const&, unsigned long, std::shared_ptr, unsigned long) @ 0x0000000038f69119 18. ./contrib/llvm-project/libcxx/include/__utility/pair.h:478: std::unique_ptr, void*>, std::__tree_node_destructor, void*>>>> std::__tree, std::__map_value_compare, std::less, true>, std::allocator>>::__construct_node, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>>(std::piecewise_construct_t const&, std::tuple&&, std::tuple const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&>&&) @ 0x0000000038f68c08 19. ./contrib/llvm-project/libcxx/include/__tree:1779: std::pair, std::__tree_node, void*>*, long>>, bool> std::map, std::allocator>>::try_emplace[abi:ne190107] const&, String const&, unsigned long, std::shared_ptr&, unsigned long const&>(String const&, std::shared_ptr const&, String const&, unsigned long&&, std::shared_ptr&, unsigned long const&) @ 0x0000000038f67d83 20. ./build_docker/./src/Storages/StorageLog.cpp:500: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000038f5a1c3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 22. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 23. ./build_docker/./src/Storages/StorageLog.cpp:487: DB::LogSink::writeData(DB::NameAndTypePair const&, DB::IColumn const&) @ 0x0000000038f3cb45 24. ./build_docker/./src/Storages/StorageLog.cpp:420: DB::LogSink::consume(DB::Chunk&) @ 0x0000000038f3c493 25. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 28. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:28:24.509252 [ 3739 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.53 MiB (attempt to allocate chunk of 1.27 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_148_33/data.bin (position: 404432, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 69cae3fbc864c9f6c8851516dfc9bb8b828fbd020000001000): (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_148_33/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 0 with max_rows_to_read = 8230): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 16. ./src/IO/ReadHelpers.h:117: DB::SerializationLowCardinality::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f697089 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:61: DB::SerializationNamed::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6c06fb 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:730: DB::SerializationTuple::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f7e8a8b 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:293: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f5ae089 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:452: DB::SerializationMap::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6b6e8e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:290: DB::MergeTreeReaderCompact::readPrefix(DB::NameAndTypePair const&, std::shared_ptr const&, std::shared_ptr&, std::function const&) @ 0x0000000039e8f707 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:274: DB::MergeTreeReaderCompact::readPrefix(unsigned long, DB::MergeTreeReaderStream&) @ 0x0000000039e8ef62 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:52: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed659b 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:24.512673 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.53 MiB (attempt to allocate chunk of 1.27 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_148_33/data.bin (position: 404432, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 69cae3fbc864c9f6c8851516dfc9bb8b828fbd020000001000): (while reading column attribute): (while reading from part /var/lib/clickhouse/store/91a/91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53/202511_1_148_33/ in table system.opentelemetry_span_log (91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53) located on disk default of type local, from mark 0 with max_rows_to_read = 8230): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000001f9601d1 16. ./src/IO/ReadHelpers.h:117: DB::SerializationLowCardinality::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f697089 17. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:61: DB::SerializationNamed::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6c06fb 18. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:730: DB::SerializationTuple::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f7e8a8b 19. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:293: DB::SerializationArray::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f5ae089 20. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:452: DB::SerializationMap::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x000000002f6b6e8e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:290: DB::MergeTreeReaderCompact::readPrefix(DB::NameAndTypePair const&, std::shared_ptr const&, std::shared_ptr&, std::function const&) @ 0x0000000039e8f707 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:274: DB::MergeTreeReaderCompact::readPrefix(unsigned long, DB::MergeTreeReaderStream&) @ 0x0000000039e8ef62 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:52: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed659b 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 26. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 28. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 29. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:24.529041 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 469.77 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading column value7): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:24.531262 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 469.77 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: (while reading column value7): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:24.616878 [ 19621 ] {b9ed68eb-444e-4ab1-82a4-782272dd517d} executeQuery: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 39, line 55) (in query: select multiFuzzyMatchAllIndices(materialize('123'), 0, materialize(['12']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c424a0 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:24.706192 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Regexp length too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['12']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['12']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long&) @ 0x0000000020e6cecd 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e6fbd 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c424a0 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:25.398604 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:25.400446 [ 17228 ] {} DynamicQueryHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 445.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, unsigned long) @ 0x000000001fcb1c95 11. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:194: DB::WriteBufferFromPocoSocket::WriteBufferFromPocoSocket(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcb2306 12. ./src/Server/HTTP/HTTPServerResponse.h:89: DB::WriteBufferFromHTTPServerResponse::WriteBufferFromHTTPServerResponse(DB::HTTPServerResponse&, bool, StrongTypedef const&) @ 0x000000003af4696a 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acd8816 14. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 17. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 20. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:25.414191 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.55 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:25.416915 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.55 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:25.773078 [ 3731 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:25.775736 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:25.787461 [ 19619 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.02 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:26.176692 [ 19621 ] {d404853b-d30c-47e0-b2ae-9da89331702e} executeQuery: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:58738) (comment: 02004_max_hyperscan_regex_length.sql) (query 40, line 56) (in query: select multiFuzzyMatchAllIndices(materialize('123'), 0, materialize(['1', '2']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c424a0 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:26.210956 [ 19621 ] {} TCPHandler: Code: 36. DB::Exception: Total regexp lengths too large (2 > 1): while executing 'FUNCTION multiFuzzyMatchAllIndices(materialize('123'_String) :: 4, 0_UInt8 :: 2, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String)) :: 1) -> multiFuzzyMatchAllIndices(materialize('123'_String), 0_UInt8, materialize(_CAST(['1', '2']_Array(String), 'Array(String)'_String))) Array(UInt64) : 3'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b20396d 4. DB::checkHyperscanRegexp(std::vector>, std::allocator>>> const&, unsigned long, unsigned long) @ 0x000000002c2e712d 5. DB::FunctionsMultiStringFuzzySearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016c424a0 6. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 10. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 12. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:26.388764 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_119_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 522.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:26.389481 [ 3730 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_166_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.56 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(long const*, long const*) @ 0x000000001f87c9fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037ba7541 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8bc22 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:26.391799 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_119_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 522.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 22. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 23. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 24. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 28. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:26.391799 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_166_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 444.56 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(long const*, long const*) @ 0x000000001f87c9fd 13. ./src/Columns/ColumnVector.h:51: DB::ColumnVector::ColumnVector(DB::ColumnVector const&) @ 0x0000000037ba7541 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnFixedSizeHelper>, DB::ColumnVector>::clone() const @ 0x0000000037c8bc22 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 22. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:26.574271 [ 16215 ] {5c2cf262-b158-482e-adb5-3ab9ed019a0c} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.52 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:36980) (comment: 00834_kill_mutation_replicated_zookeeper.sh) (query 1, line 1) (in query: SELECT count() FROM system.mutations WHERE database = 'test_rr6dqsl7' AND table = 'kill_mutation_r1' AND is_done = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:28:26.588031 [ 3732 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.54 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:26.590734 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 462.54 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:26.600049 [ 16215 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 461.52 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:26.605152 [ 17385 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.45 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:26.606579 [ 17385 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 459.45 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:26.758081 [ 3726 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.53 MiB (attempt to allocate chunk of 1.52 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column symbols): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000a39c15c 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e27fe 13. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:596: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69c395 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:26.760820 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.53 MiB (attempt to allocate chunk of 1.52 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: (while reading column symbols): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000a39c15c 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e27fe 13. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:596: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69c395 14. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:27.589376 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:27.590676 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 406.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:27.603922 [ 16354 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:27.605163 [ 16354 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.25 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:27.615721 [ 3724 ] {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.68 MiB (attempt to allocate chunk of 2.42 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000377819cd 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 21. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 23. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 24. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 25. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375e8ff1 27. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 28. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 30. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:27.617771 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {91ae5c3f-e8e0-4fc1-a850-0dc2ce9c0a53::202511_1_154_34}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.68 MiB (attempt to allocate chunk of 2.42 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::alloc_for_num_elements(unsigned long) @ 0x000000001f87707a 12. ./src/Common/PODArray.h:347: DB::PODArray, 63ul, 64ul>::PODArray(unsigned long const*, unsigned long const*) @ 0x000000001f8773fd 13. ./build_docker/./src/Columns/ColumnString.cpp:32: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de711 14. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 15. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 16. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 17. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000377819cd 19. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 20. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 21. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000370f8d04 23. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 24. DB::IColumn::mutate(COW::immutable_ptr)::'lambda'(COW::chameleon_ptr&)::operator()(COW::chameleon_ptr&) const @ 0x0000000008e6eb7a 25. void std::__function::__policy_invoker::chameleon_ptr&)>::__call_impl[abi:ne190107]::immutable_ptr)::'lambda'(COW::chameleon_ptr&), void (COW::chameleon_ptr&)>>(std::__function::__policy_storage const*, COW::chameleon_ptr&) @ 0x0000000008e6ea69 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000375e8ff1 27. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e388 28. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 29. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 30. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:27.980307 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.26 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:27.982704 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 435.26 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.075611 [ 3732 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.078351 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 434.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.276954 [ 18106 ] {42ee2010-0822-4bac-b011-47da931df842} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.16 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.63 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37034) (comment: 03164_optimize_read_in_order_nullable.sql) (query 4, line 6) (in query: INSERT INTO 03164_users VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:28:28.320512 [ 18149 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.74 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.321955 [ 18149 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.74 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.409595 [ 18106 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.16 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.63 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:28:28.437745 [ 19618 ] {b7fedc38-755c-4191-8018-df546f8ecbdf} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.15 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.76 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37104) (comment: 00834_kill_mutation_replicated_zookeeper.sh) (query 1, line 1) (in query: SELECT count() FROM system.mutations WHERE database = 'test_rr6dqsl7' AND table = 'kill_mutation_r1' AND is_done = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 2025.11.13 09:28:28.515411 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.42 MiB (attempt to allocate chunk of 1.33 MiB bytes), current RSS: 15.73 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.517685 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.42 MiB (attempt to allocate chunk of 1.33 MiB bytes), current RSS: 15.73 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.609996 [ 3734 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_92_100_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.71 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_97_97_0/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 15): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.612525 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_92_100_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.42 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.71 GiB, maximum: 15.30 GiB.: (while reading from part /var/lib/clickhouse/store/28d/28d340b3-054b-4893-b34c-fc5bc83129ec/202511_97_97_0/ in table system.metric_log (28d340b3-054b-4893-b34c-fc5bc83129ec) located on disk default of type local, from mark 0 with max_rows_to_read = 15): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x0000000008c48d94 12. ./src/Common/PODArray.h:428: DB::ColumnVector::insertDefault() @ 0x0000000037b17b55 13. ./build_docker/./src/Columns/ColumnSparse.cpp:30: DB::ColumnSparse::ColumnSparse(COW::mutable_ptr&&) @ 0x00000000376bec76 14. ./src/Common/COW.h:293: DB::IDataType::createColumn(DB::ISerialization const&) const @ 0x000000002f4b3afa 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:304: DB::MergeTreeReaderCompact::createColumnsForReading(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000039e8fc7c 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:23: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed5eab 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.642403 [ 19618 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.15 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.76 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 19. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 21. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 22. ? @ 0x00007fa150622ac3 23. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:28.728860 [ 17228 ] {ccf4f015-dd03-4fcc-99ae-be1c6f4d4439} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.45 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.58 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37056) (comment: 02885_arg_min_max_combinator.sql) (query 2, line 2) (in query: select sumArgMin(number, toString(number % 20)), sumArgMax(number, toString(number % 20)) from numbers(100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:28.747320 [ 18106 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 392.46 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.66 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.748464 [ 18106 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 392.46 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.66 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.761696 [ 3738 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 392.51 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.66 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.763772 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 392.51 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.66 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.772950 [ 17228 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.45 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.58 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:28.805551 [ 18106 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.62 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.848705 [ 18106 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.849946 [ 18106 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.869422 [ 3729 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.53 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.870523 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.871483 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.53 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.871561 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.51 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.909980 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.913794 [ 18106 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.920073 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.921051 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.926647 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.48 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.932826 [ 17228 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:28.933621 [ 17228 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.050529 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.051560 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.53 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.057848 [ 3727 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_167_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.55 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_166_166_0/data.bin (position: 29049, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: c89e6102692fc23d21b34d4c591a618182a51d0000f6980200): (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_166_166_0/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 1678): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.060282 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_167_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 395.55 MiB (attempt to allocate chunk of 1.03 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_166_166_0/data.bin (position: 29049, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: c89e6102692fc23d21b34d4c591a618182a51d0000f6980200): (while reading column path): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_166_166_0/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 0 with max_rows_to_read = 1678): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.065444 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.066526 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.104556 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.126793 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.46 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.261869 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.262979 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.00 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.306332 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 403.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.309676 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 403.81 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.42 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.406504 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.407543 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.427282 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.428273 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 407.63 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.560024 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.561064 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.562546 [ 16889 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.563610 [ 16889 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 393.19 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.670546 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.675054 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:29.677844 [ 16889 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 375.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.097437 [ 16920 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.92 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.137279 [ 16920 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.138872 [ 16920 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.140441 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.143314 [ 16920 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.275440 [ 3736 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.87 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.277618 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 457.87 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.312398 [ 18106 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.323566 [ 4170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.324742 [ 4170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.350358 [ 3728 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.31 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_73_73_0/data.bin (position: 43295, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 8e173fabe970ffcb2e72987766ee84488213450000d05b0900): (while reading column trace): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_73_73_0/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 2066): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b006e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.352398 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 456.31 MiB (attempt to allocate chunk of 1.45 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_73_73_0/data.bin (position: 43295, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 8e173fabe970ffcb2e72987766ee84488213450000d05b0900): (while reading column trace): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_73_73_0/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 2066): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b006e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 22. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 23. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:30.611940 [ 17228 ] {c3d7f27e-f075-4b4b-a6d7-19513c7c42a9} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.00 MiB (attempt to allocate chunk of 3.82 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION range(__table1.number :: 2) -> range(__table1.number) Array(UInt64) : 0'. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37180) (comment: 03230_async_insert_native.sh) (query 1, line 1) (in query: SELECT (range(number), range(number))::Map(UInt64, UInt64) AS m FROM numbers(1000) FORMAT Native), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037b1704e 12. COW::immutable_ptr DB::FunctionRange::executeInternal(DB::IColumn const*) const @ 0x000000001f561f39 13. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f558f41 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 20. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 2025.11.13 09:28:30.704843 [ 17228 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.00 MiB (attempt to allocate chunk of 3.82 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: while executing 'FUNCTION range(__table1.number :: 2) -> range(__table1.number) Array(UInt64) : 0'. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::ColumnVector::ColumnVector(unsigned long) @ 0x0000000037b1704e 12. COW::immutable_ptr DB::FunctionRange::executeInternal(DB::IColumn const*) const @ 0x000000001f561f39 13. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f558f41 14. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 18. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 20. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 21. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 26. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 29. ? @ 0x00007fa150622ac3 30. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.005495 [ 4170 ] {770462d3-9edd-4cdc-8e83-b93f0bdbefe9} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34528) (comment: 02921_database_filesystem_path_check.sql) (query 1, line 1) (in query: create database db_filesystem ENGINE=Filesystem('/etc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6d45 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.014280 [ 4170 ] {} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6d45 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.038983 [ 4170 ] {8bfab595-e173-4c55-9048-67c448eef3e0} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34528) (comment: 02921_database_filesystem_path_check.sql) (query 2, line 2) (in query: create database db_filesystem ENGINE=Filesystem('../../../../../../../../etc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6d45 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.106043 [ 3734 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:31.107878 [ 3731 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 441.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:31.108094 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 442.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:31.109977 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 441.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:31.139634 [ 4170 ] {} TCPHandler: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000008c3686a 4. ./build_docker/./src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x000000002f8e6d45 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x000000002f8f3c64 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:ne190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x000000002f8ef868 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f8dd92b 8. ./build_docker/./src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x000000002f8dc227 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b8182 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.140713 [ 3724 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 439.61 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:31.142726 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 439.61 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:31.469170 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_257_262_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.48 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:31.471112 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_257_262_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.48 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:31.509944 [ 3726 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_167_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.88 MiB (attempt to allocate chunk of 1.40 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:31.511857 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_167_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.88 MiB (attempt to allocate chunk of 1.40 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::PODArray, 63ul, 64ul>::PODArray(char8_t const*, char8_t const*) @ 0x000000001f871e40 12. ./build_docker/./src/Columns/ColumnString.cpp:33: DB::ColumnString::ColumnString(DB::ColumnString const&) @ 0x00000000376de750 13. ./src/Common/COW.h:298: COWHelper, DB::ColumnString>::clone() const @ 0x00000000377076c2 14. DB::IColumn::mutate(COW::immutable_ptr) @ 0x0000000008e6e24b 15. ./build_docker/./src/Core/Block.cpp:541: DB::Block::mutateColumns() @ 0x000000002eb00918 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:194: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba67b9 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::write(DB::Block const&) @ 0x000000003a05e3c5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:887: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2f60 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 21. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 26. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 30. ? @ 0x00007fa150622ac3 31. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:31.515642 [ 16361 ] {acb4a003-43df-4c3b-b915-fc863a884018} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 415.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35374) (comment: 03261_pr_semi_anti_join.sql) (query 10, line 14) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`s` AS `s`, `__table2`.`x` AS `t2.x`, `__table2`.`s` AS `t2.s` FROM `test_56bc3cpn`.`t1` AS `__table1` SEMI LEFT JOIN `test_56bc3cpn`.`t2` AS `__table2` USING (`x`) ORDER BY `__table1`.`x` ASC, `__table2`.`x` ASC, `__table1`.`s` ASC, `__table2`.`s` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.552131 [ 16361 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 415.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.611062 [ 16889 ] {18847605-d8da-4970-b7ff-c251b86c4e65} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 392.90 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37264) (comment: 00091_union_race_conditions_2.sh) (query 4, line 4) (in query: SELECT count() FROM (SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.638827 [ 16889 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 392.90 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.751205 [ 17385 ] {2e130fff-e966-4a7d-837f-9223213a821c} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 415.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37112) (comment: 03261_pr_semi_anti_join.sql) (query 10, line 14) (in query: SELECT t1.*, t2.* FROM t1 SEMI LEFT JOIN t2 USING(x) ORDER BY t1.x, t2.x, t1.s, t2.s;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 2025.11.13 09:28:31.781359 [ 19178 ] {d40cf00f-5faf-4367-b195-b06b6e8a2918} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:56788). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56788) (comment: 03261_pr_semi_anti_join.sql) (query 10, line 14) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`s` AS `s`, `__table2`.`x` AS `t2.x`, `__table2`.`s` AS `t2.s` FROM `test_56bc3cpn`.`t1` AS `__table1` SEMI LEFT JOIN `test_56bc3cpn`.`t2` AS `__table2` USING (`x`) ORDER BY `__table1`.`x` ASC, `__table2`.`x` ASC, `__table1`.`s` ASC, `__table2`.`s` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x000000003aea4d5d 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.786763 [ 18725 ] {bbfdc824-4e5b-4388-9d24-cfe022058e09} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:34708). (NETWORK_ERROR) (version 25.3.8.10072.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34708) (comment: 03261_pr_semi_anti_join.sql) (query 10, line 14) (in query: SELECT `__table1`.`x` AS `x`, `__table1`.`s` AS `s`, `__table2`.`x` AS `t2.x`, `__table2`.`s` AS `t2.s` FROM `test_56bc3cpn`.`t1` AS `__table1` SEMI LEFT JOIN `test_56bc3cpn`.`t2` AS `__table2` USING (`x`) ORDER BY `__table1`.`x` ASC, `__table2`.`x` ASC, `__table1`.`s` ASC, `__table2`.`s` ASC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed4b32 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.791355 [ 17385 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: (total) memory limit exceeded: would use 415.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr, 0>(std::allocator const&, DB::WriteBufferFromPocoSocketChunked&, std::shared_ptr&&) @ 0x000000003af1a698 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x000000003af00773 15. ./build_docker/./src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x000000003aef715a 16. ./build_docker/./src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed42d5 17. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 18. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 20. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 23. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 24. ? @ 0x00007fa150622ac3 25. ? @ 0x00007fa1506b4850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003ab9a738 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x000000002f2ea614 7. ./build_docker/./src/Common/AsyncTaskExecutor.cpp:88: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x000000002f2e7ed9 8. ./src/Common/Fiber.h:76: boost::context::detail::fiber_capture_record>::run() @ 0x000000002f2e7245 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:81: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x000000002f2e4992 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.802978 [ 19178 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:56788). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb0fa3 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x000000003aea4d5d 7. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 9. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 12. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 13. ? @ 0x00007fa150622ac3 14. ? @ 0x00007fa1506b4850 2025.11.13 09:28:31.822575 [ 18725 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:34708). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001fcace7d 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001fcb1536 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:116: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003aace8ea 5. DB::WriteBuffer::next() @ 0x0000000008c37ea1 6. ./build_docker/./src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed4b32 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:32.156817 [ 18721 ] {c6609d81-3e81-4fa3-bb03-8674c3568296} executeQuery: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34580) (comment: 02889_print_pretty_type_names.sql) (query 1, line 1) (in query: create table test (a Tuple(b String, c Tuple(d Nullable(UInt64), e Array(UInt32), f Array(Tuple(g String, h Map(String, Array(Tuple(i String, j UInt64))))), k Date), l Nullable(String))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:28:32.171785 [ 18721 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:28:32.359859 [ 3731 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 519.06 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_239_247_1/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9363): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:32.362250 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 519.06 MiB (attempt to allocate chunk of 1.50 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_239_247_1/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9363): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:32.371085 [ 16920 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:32.372253 [ 16920 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 505.69 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:32.373660 [ 3735 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 502.64 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/event_time_microseconds.bin (position: 39458, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 244fb0ee346db874fbf6806eaa27d49782129a000000000100): (while reading column event_time_microseconds): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationDecimalBase.cpp:63: DB::SerializationDecimalBase::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f5f4be7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 23. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:32.375996 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 502.64 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/event_time_microseconds.bin (position: 39458, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 244fb0ee346db874fbf6806eaa27d49782129a000000000100): (while reading column event_time_microseconds): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationDecimalBase.cpp:63: DB::SerializationDecimalBase::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f5f4be7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 23. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:32.379001 [ 16920 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 491.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:32.379958 [ 16920 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 491.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:32.578702 [ 16186 ] {287789db-fe14-42cf-b0b0-ebbac437b0ed} PushingToViews: Failed to push block to view test_6051lzvn.mv (818f9d70-e20a-4210-a5d7-3623f7f96484), 2025.11.13 09:28:32.781036 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 467.93 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:32.783541 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 467.93 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.163601 [ 4936 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 439.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.164818 [ 4936 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 439.54 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.218524 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 441.61 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.220630 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 441.61 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.329478 [ 18700 ] {78767b97-49c9-4cc3-9fb4-dc10aa69a440} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34650) (comment: 00875_join_right_nulls.sql) (query 3, line 4) (in query: CREATE TABLE t (`x` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 52142, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 481745349, compact_parts_max_granules_to_buffer = 243, compact_parts_merge_max_bytes_to_prefetch_part = 14184667, merge_max_block_size = 20583, old_parts_lifetime = 140., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1814592851, index_granularity_bytes = 11163228, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 35, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 89337, primary_key_compress_block_size = 50637, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:28:33.357062 [ 18700 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000032a1c8f1 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe9cb 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 9. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 10. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 12. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 15. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 16. ? @ 0x00007fa150622ac3 17. ? @ 0x00007fa1506b4850 2025.11.13 09:28:33.364478 [ 3724 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.10 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.366732 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 436.10 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:182: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f7a77c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.458879 [ 16920 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.459877 [ 16920 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.99 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.476965 [ 3739 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_167_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.00 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column query_id): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 9167): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.479281 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_167_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.00 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB.: (while reading column query_id): (while reading from part /var/lib/clickhouse/store/915/915c40e0-d888-4224-992b-0533c5fa32c1/202511_107_158_10/ in table system.zookeeper_log (915c40e0-d888-4224-992b-0533c5fa32c1) located on disk default of type local, from mark 2 with max_rows_to_read = 9167): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70dd 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 19. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 20. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.491162 [ 16920 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 390.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:33.798516 [ 16186 ] {287789db-fe14-42cf-b0b0-ebbac437b0ed} executeQuery: Poco::Exception. Code: 1000, e.code() = 111, Connection refused (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34582) (comment: 03322_materialized_view_ignore_errors_url.sql) (query 7, line 11) (in query: INSERT INTO src SETTINGS materialized_views_ignore_errors = 0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::IOException::IOException(String const&, int) @ 0x0000000041336ba6 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::ConnectionRefusedException::ConnectionRefusedException(String const&, int) @ 0x000000004151ef0e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:1002: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000415455d6 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:928: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000415486b9 4. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x000000004155464e 5. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000414e6508 6. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x00000000414a6668 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020208e61 8. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020205de5 9. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020231c84 10. ./build_docker/./src/IO/WriteBufferFromHTTP.cpp:21: DB::WriteBufferFromHTTP::WriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, String const&, String const&, std::vector> const&, DB::ConnectionTimeouts const&, unsigned long, DB::ProxyConfiguration) @ 0x000000002022f283 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]> const&, DB::ConnectionTimeouts const&, unsigned long long const&, DB::ProxyConfiguration&>(DB::HTTPConnectionGroupType&&, Poco::URI&, String const&, String&, String&, std::vector> const&, DB::ConnectionTimeouts const&, unsigned long long const&, DB::ProxyConfiguration&) @ 0x0000000038e8c6f3 12. ./build_docker/./src/Storages/StorageURL.cpp:634: DB::StorageURLSink::StorageURLSink(String const&, String const&, std::optional const&, DB::Block const&, std::shared_ptr const&, DB::ConnectionTimeouts const&, DB::CompressionMethod, std::vector> const&, String const&) @ 0x0000000038e637f0 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::IStorageURLBase::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000038e7012c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd6d680 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:343: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000032acb542 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:376: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003bd5f11d 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd699ce 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 20. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000032ad1b23 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ada2a3 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000032adffb3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:28:33.808522 [ 16186 ] {} TCPHandler: Code: 1000. DB::Exception: Connection refused. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::IOException::IOException(String const&, int) @ 0x0000000041336ba6 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::ConnectionRefusedException::ConnectionRefusedException(String const&, int) @ 0x000000004151ef0e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:1002: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000415455d6 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:928: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000415486b9 4. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x000000004155464e 5. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000414e6508 6. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x00000000414a6668 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020208e61 8. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020205de5 9. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020231c84 10. ./build_docker/./src/IO/WriteBufferFromHTTP.cpp:21: DB::WriteBufferFromHTTP::WriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, String const&, String const&, std::vector> const&, DB::ConnectionTimeouts const&, unsigned long, DB::ProxyConfiguration) @ 0x000000002022f283 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]> const&, DB::ConnectionTimeouts const&, unsigned long long const&, DB::ProxyConfiguration&>(DB::HTTPConnectionGroupType&&, Poco::URI&, String const&, String&, String&, std::vector> const&, DB::ConnectionTimeouts const&, unsigned long long const&, DB::ProxyConfiguration&) @ 0x0000000038e8c6f3 12. ./build_docker/./src/Storages/StorageURL.cpp:634: DB::StorageURLSink::StorageURLSink(String const&, String const&, std::optional const&, DB::Block const&, std::shared_ptr const&, DB::ConnectionTimeouts const&, DB::CompressionMethod, std::vector> const&, String const&) @ 0x0000000038e637f0 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::IStorageURLBase::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000038e7012c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd6d680 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:343: DB::InterpreterInsertQuery::buildChain(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::vector> const&, std::shared_ptr, std::atomic*, bool) @ 0x0000000032acb542 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:376: DB::generateViewChain(std::shared_ptr, unsigned long, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000003bd5f11d 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:530: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd699ce 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 20. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000032ad1b23 21. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ada2a3 22. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000032adffb3 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 25. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 26. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 28. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 31. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 2025.11.13 09:28:33.902788 [ 16186 ] {568cdcce-466c-4f0f-9bec-7f9380f28a8d} PushingToViews: Failed to push block to view test_6051lzvn.mv (818f9d70-e20a-4210-a5d7-3623f7f96484), 2025.11.13 09:28:34.234386 [ 3728 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:34.236450 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 470.75 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:34.255623 [ 16207 ] {60044df9-f97d-4331-9716-8b8e4c63121c} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.69 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34664) (comment: 00091_union_race_conditions_2.sh) (query 1, line 1) (in query: SELECT count() FROM (SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:34.285895 [ 16207 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 398.69 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:34.727323 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 574.21 MiB (attempt to allocate chunk of 1.60 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/data.bin (position: 340335, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 086cb579b4cfc1e7fdfe951fc3d2c77f82f0c8020000001000): (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:34.729160 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 574.21 MiB (attempt to allocate chunk of 1.60 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/data.bin (position: 340335, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 086cb579b4cfc1e7fdfe951fc3d2c77f82f0c8020000001000): (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4c8c 12. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 14. DB::ReadBuffer::next() @ 0x0000000008ef7cef 15. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.056492 [ 4936 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 443.38 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.057726 [ 4936 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 443.38 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.062446 [ 3737 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.44 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/symbols.bin (position: 31660, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 84c65ef02d0e469f6f470579bea0cedd829c7b0000fa1d0800): (while reading column symbols): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 15. DB::ReadBuffer::next() @ 0x0000000008ef7cef 16. ./src/IO/ReadBuffer.h:96: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69affa 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.064644 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 454.44 MiB (attempt to allocate chunk of 1.28 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/symbols.bin (position: 31660, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 84c65ef02d0e469f6f470579bea0cedd829c7b0000fa1d0800): (while reading column symbols): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 15. DB::ReadBuffer::next() @ 0x0000000008ef7cef 16. ./src/IO/ReadBuffer.h:96: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69affa 17. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.283904 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.284978 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.18 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.307151 [ 17227 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.308275 [ 17227 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.16 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.660593 [ 3724 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 573.68 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6c57c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.662727 [ 3724 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 573.68 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:57: DB::SerializationNullable::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f6c57c1 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.746792 [ 3727 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.748735 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 452.05 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: (while reading column value2): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.953356 [ 3738 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 404.98 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:35.955505 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 404.98 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:36.015053 [ 16207 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:36.016213 [ 16207 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:36.026506 [ 3728 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.25 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:36.028476 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.25 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:36.048569 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 1361 entries up to offset 505723: Code: 241. DB::Exception: (total) memory limit exceeded: would use 388.73 MiB (attempt to allocate chunk of 4.47 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 11. ./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:ne190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x0000000039bb8679 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039baf8a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039ba52d5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:68: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba4689 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 18. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 19. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 26. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 31. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:36.166828 [ 16186 ] {9cfdebd4-b72c-4b3f-941c-8e7f9d745182} executeQuery: Poco::Exception. Code: 1000, e.code() = 111, Connection refused (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34582) (comment: 03322_materialized_view_ignore_errors_url.sql) (query 13, line 21) (in query: -- Ensure this still fails insert into function url('http://127.0.0.1/foo.tsv', 'TabSeparated', 'key Int') settings http_max_tries=1, materialized_views_ignore_errors=1 values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::IOException::IOException(String const&, int) @ 0x0000000041336ba6 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::ConnectionRefusedException::ConnectionRefusedException(String const&, int) @ 0x000000004151ef0e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:1002: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000415455d6 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:928: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000415486b9 4. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x000000004155464e 5. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000414e6508 6. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x00000000414a6668 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020208e61 8. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020205de5 9. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020231c84 10. ./build_docker/./src/IO/WriteBufferFromHTTP.cpp:21: DB::WriteBufferFromHTTP::WriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, String const&, String const&, std::vector> const&, DB::ConnectionTimeouts const&, unsigned long, DB::ProxyConfiguration) @ 0x000000002022f283 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]> const&, DB::ConnectionTimeouts const&, unsigned long long const&, DB::ProxyConfiguration&>(DB::HTTPConnectionGroupType&&, Poco::URI&, String const&, String&, String&, std::vector> const&, DB::ConnectionTimeouts const&, unsigned long long const&, DB::ProxyConfiguration&) @ 0x0000000038e8c6f3 12. ./build_docker/./src/Storages/StorageURL.cpp:634: DB::StorageURLSink::StorageURLSink(String const&, String const&, std::optional const&, DB::Block const&, std::shared_ptr const&, DB::ConnectionTimeouts const&, DB::CompressionMethod, std::vector> const&, String const&) @ 0x0000000038e637f0 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::IStorageURLBase::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000038e7012c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd6d680 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000032ad1b23 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ada2a3 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000032adffb3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:28:36.177197 [ 16186 ] {} TCPHandler: Code: 1000. DB::Exception: Connection refused. (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::IOException::IOException(String const&, int) @ 0x0000000041336ba6 1. ./build_docker/./base/poco/Net/src/NetException.cpp:26: Poco::Net::ConnectionRefusedException::ConnectionRefusedException(String const&, int) @ 0x000000004151ef0e 2. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:1002: Poco::Net::SocketImpl::error(int, String const&) @ 0x00000000415455d6 3. ./build_docker/./base/poco/Net/src/SocketImpl.cpp:928: Poco::Net::SocketImpl::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x00000000415486b9 4. ./build_docker/./base/poco/Net/src/StreamSocket.cpp:84: Poco::Net::StreamSocket::connect(Poco::Net::SocketAddress const&, Poco::Timespan const&) @ 0x000000004155464e 5. ./build_docker/./base/poco/Net/src/HTTPSession.cpp:227: Poco::Net::HTTPSession::connect(Poco::Net::SocketAddress const&) @ 0x00000000414e6508 6. ./build_docker/./base/poco/Net/src/HTTPClientSession.cpp:471: Poco::Net::HTTPClientSession::reconnect(unsigned long*) @ 0x00000000414a6668 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:502: DB::EndpointConnectionPool::prepareNewConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020208e61 8. ./build_docker/./src/Common/HTTPConnectionPool.cpp:590: DB::EndpointConnectionPool::getConnection(DB::ConnectionTimeouts const&, unsigned long*) @ 0x0000000020205de5 9. ./build_docker/./src/IO/HTTPCommon.cpp:63: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&, unsigned long*) @ 0x0000000020231c84 10. ./build_docker/./src/IO/WriteBufferFromHTTP.cpp:21: DB::WriteBufferFromHTTP::WriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, String const&, String const&, std::vector> const&, DB::ConnectionTimeouts const&, unsigned long, DB::ProxyConfiguration) @ 0x000000002022f283 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]> const&, DB::ConnectionTimeouts const&, unsigned long long const&, DB::ProxyConfiguration&>(DB::HTTPConnectionGroupType&&, Poco::URI&, String const&, String&, String&, std::vector> const&, DB::ConnectionTimeouts const&, unsigned long long const&, DB::ProxyConfiguration&) @ 0x0000000038e8c6f3 12. ./build_docker/./src/Storages/StorageURL.cpp:634: DB::StorageURLSink::StorageURLSink(String const&, String const&, std::optional const&, DB::Block const&, std::shared_ptr const&, DB::ConnectionTimeouts const&, DB::CompressionMethod, std::vector> const&, String const&) @ 0x0000000038e637f0 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::IStorageURLBase::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000038e7012c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:630: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, unsigned long, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000003bd6d680 15. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:380: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000032acc62b 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x0000000032ad1b23 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000032ada2a3 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000032adffb3 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 21. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 22. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 24. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 27. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 28. ? @ 0x00007fa150622ac3 29. ? @ 0x00007fa1506b4850 2025.11.13 09:28:36.313120 [ 3733 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_92_100_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.26 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:36.315385 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_92_100_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.26 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:36.550253 [ 3730 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.72 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:36.552507 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 400.72 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:36.558152 [ 4936 ] {ab2658a2-bacb-4a0a-8019-05bf465235a1} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.65 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34788) (comment: 00091_union_race_conditions_2.sh) (query 4, line 4) (in query: SELECT count() FROM (SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:36.565977 [ 18403 ] {f4adcecb-d93a-417d-a4e2-c9e21b5f1c53} executeQuery: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34848) (comment: 02995_forget_partition.sh) (query 2, line 4) (in query: CREATE TABLE forget_partition (`k` UInt64, `d` Date, `v` String) ENGINE = ReplicatedMergeTree('/test/02995/{database}/rmt', '1') PARTITION BY toYYYYMMDD(d) ORDER BY (k, d) SETTINGS old_parts_lifetime = 5, merge_selecting_sleep_ms = 1000, max_merge_selecting_sleep_ms = 5000, cleanup_delay_period = 3, max_cleanup_delay_period = 5, index_granularity = 50696, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 394523009, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18144362, merge_max_block_size = 21229, prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 399580, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 22322852, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 35, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 21434, primary_key_compress_block_size = 79419, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:28:36.580104 [ 18403 ] {} TCPHandler: Code: 80. DB::Exception: Explicit zookeeper_path and replica_name are specified in ReplicatedMergeTree arguments. If you really want to specify it explicitly, then you should use some macros to distinguish different shards and replicas. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x000000002f9d1f34 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002f9d86df 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x000000002f9da2c2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000329fe242 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2355: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be75 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 11. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 12. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 14. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 17. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 18. ? @ 0x00007fa150622ac3 19. ? @ 0x00007fa1506b4850 2025.11.13 09:28:36.582293 [ 4936 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.65 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:37.214975 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 497.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.217050 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 497.26 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.338736 [ 3737 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.11 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.341144 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 489.11 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.450708 [ 3736 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.55 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.453105 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 394.55 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.619233 [ 16920 ] {eabd2dee-a7bf-40a5-9821-01d5c5e02993} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34762) (comment: 03131_rewrite_sum_if_nullable.sql) (query 9, line 12) (in query: SELECT sumOrNull(if(materialize(0), toNullable(1), 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:28:37.690954 [ 16920 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabf4ec 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 11. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:37.943316 [ 3730 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.26 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.945383 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.26 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.960928 [ 3729 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.27 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.962950 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.27 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.977423 [ 3727 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 428.61 MiB (attempt to allocate chunk of 1.33 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.979754 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 428.61 MiB (attempt to allocate chunk of 1.33 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:37.980645 [ 3903 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::QueryLogElement]: Failed to flush system log system.query_log with 330 entries up to offset 67176: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.27 MiB (attempt to allocate chunk of 4.01 MiB bytes), current RSS: 15.39 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 10. ./build_docker/./src/Columns/ColumnString.cpp:366: COW::immutable_ptr DB::ColumnString::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x000000003770981d 11. ./src/Columns/ColumnsCommon.h:136: DB::ColumnString::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000376e1f2f 12. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:47: DB::permuteBlockIfNeeded(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039829bfb 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:189: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba572d 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 26. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000332cf2e1 27. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x00000000332cc91e 28. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fb9ba81 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fb9b8bf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:38.005924 [ 16207 ] {a287c484-5ee8-4e7e-a65b-e739dfc4cb1f} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.47 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34866) (comment: 03282_parallel_join_with_additional_filter.sql) (query 4, line 14) (in query: INSERT INTO t2 (key, a, attr) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:28:38.031468 [ 3734 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 428.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:38.033672 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 428.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.41 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:38.042039 [ 16207 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 419.47 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.40 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:28:38.091024 [ 18403 ] {d928ddb3-cec0-421e-b68a-e6ffe5269b83} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.53 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34904) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 1) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_replicated_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:38.243289 [ 18403 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.53 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:38.249991 [ 18700 ] {b24bc4ad-f1ba-4b64-a48a-07d32e75d238} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.50 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34870) (comment: 00091_union_race_conditions_2.sh) (query 2, line 2) (in query: SELECT count() FROM (SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:38.273816 [ 18700 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 391.50 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:39.025375 [ 3738 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.12 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.027586 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.12 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.071513 [ 3735 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.59 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.073539 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.59 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.133781 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.134791 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.232618 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.37 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.232733 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.42 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.234755 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.42 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.397675 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.398705 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 379.74 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.404226 [ 10170 ] {ff754ebb-e2a5-40c2-828b-3b104fe53584} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.20 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34942) (comment: 02543_alter_update_rename_stuck.sh) (query 1, line 1) (in query: SELECT count() from system.mutations where database='test_3' and table='table_to_rename'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:39.404226 [ 19620 ] {5e424a9a-9db4-435d-b94e-f1cac07b8f59} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.19 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34956) (comment: 00091_union_race_conditions_2.sh) (query 1, line 1) (in query: SELECT count() FROM (SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:39.411492 [ 4936 ] {ad19c844-db2b-4fdb-b82b-206d48b3c88b} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 377.82 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34926) (comment: 00961_check_table.sql) (query 5, line 8) (in query: INSERT INTO mt_table VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:28:39.422893 [ 19620 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.19 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:39.422893 [ 10170 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 378.20 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Interpreters/Aggregator.cpp:1492: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb20c7 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:707: DB::AggregatingTransform::initGenerate() @ 0x000000003baad0c3 13. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:644: DB::AggregatingTransform::work() @ 0x000000003baac70b 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5e83 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:39.429759 [ 4936 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 377.82 MiB (attempt to allocate chunk of 1.06 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba3420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 26. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 27. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 30. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 2025.11.13 09:28:39.907625 [ 3727 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 515.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:39.909724 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 515.36 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.015299 [ 3738 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.46 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.017441 [ 3738 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 494.46 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.021512 [ 18403 ] {cc0e4d5a-6b52-447b-b0fb-c28653974873} executeQuery: Code: 60. DB::Exception: Table test_5.forget_partition does not exist. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:34928) (comment: 02995_forget_partition.sh) (query 4, line 7) (in query: alter table forget_partition forget partition '20240103';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:28:40.028884 [ 4936 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 476.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.030087 [ 4936 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 476.87 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.036843 [ 18403 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.forget_partition does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000008c1242d 4. ./build_docker/./src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa6a88 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1019: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af45a6 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2053: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x000000002fa27338 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:2079: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000002fa263a7 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:126: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000003298d0b2 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x0000000032989710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:28:40.105075 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 488.24 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.107229 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 488.24 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.574002 [ 10170 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.575091 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 401.06 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.577765 [ 3727 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.28 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.579909 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 408.28 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.583344 [ 19620 ] {72a14476-776f-4a79-9210-0b75eb3fd929} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.98 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:35004) (comment: 00091_union_race_conditions_2.sh) (query 1, line 1) (in query: SELECT count() FROM (SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:40.621535 [ 19620 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 397.98 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Memory overcommit has not freed enough memory: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:1606: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000031cb456f 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003bab9c85 12. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x000000003baac848 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:40.621550 [ 3729 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.98 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:40.623932 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 396.98 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.283104 [ 3731 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.65 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.285178 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_168_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.65 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.285284 [ 3733 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_178_52} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.287485 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_178_52}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 432.64 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.383554 [ 3736 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.32 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.385625 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 448.32 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.452791 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.98 MiB (attempt to allocate chunk of 1.33 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.454718 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.98 MiB (attempt to allocate chunk of 1.33 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.657188 [ 3729 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.659087 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.58 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.681352 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 431.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.686697 [ 10170 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.29 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./src/IO/ReadBufferFromPocoSocket.h:51: DB::HTTPServerRequest::HTTPServerRequest(std::shared_ptr, DB::HTTPServerResponse&, Poco::Net::HTTPServerSession&, StrongTypedef const&) @ 0x000000003af36860 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:36: DB::HTTPServerConnection::run() @ 0x000000003af32797 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.717756 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.718753 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.726904 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.728151 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.770361 [ 3734 ] {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_178_52} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:41.772676 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {42e4c43f-6d1d-497c-bdaf-685199a73f25::202511_1_178_52}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 430.23 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.185727 [ 3735 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.69 MiB (attempt to allocate chunk of 1.11 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::shrinkToFit() @ 0x0000000037b289c4 12. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 24. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.187955 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 440.69 MiB (attempt to allocate chunk of 1.11 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnVector::shrinkToFit() @ 0x0000000037b289c4 12. ./build_docker/./src/Columns/ColumnArray.cpp:519: DB::ColumnArray::shrinkToFit() @ 0x00000000370a213e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 14. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 15. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 20. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 23. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 24. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 27. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.222090 [ 3729 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.24 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.224490 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 455.24 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.535796 [ 3727 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.49 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.595067 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.49 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.35 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.595722 [ 17390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.597001 [ 17390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 372.59 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.635704 [ 17390 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 368.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.636957 [ 17390 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 368.36 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:42.775344 [ 18403 ] {a97caf4e-e4fa-4840-956d-dcbbc43f187f} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Second takes one or two arguments: In scope SELECT fromUnixTimestamp64Second(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 1, line 1) (in query: -- -- Error cases SELECT fromUnixTimestamp64Second();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95d43 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:42.785236 [ 18403 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Second takes one or two arguments: In scope SELECT fromUnixTimestamp64Second(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95d43 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:42.824444 [ 18403 ] {d746de80-9bde-4b71-b5bf-4521617985c7} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 2, line 3) (in query: SELECT fromUnixTimestamp64Milli();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95d43 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:42.833608 [ 18403 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95d43 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:42.877049 [ 18403 ] {75cc674a-4c56-4dea-8394-0bf3328d8fd8} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 3, line 4) (in query: SELECT fromUnixTimestamp64Micro();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95d43 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:42.913652 [ 18403 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95d43 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:42.951684 [ 18403 ] {bc59c681-6109-489b-92d9-1fc02f4b2fd3} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 4, line 5) (in query: SELECT fromUnixTimestamp64Nano();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95d43 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:42.960224 [ 18403 ] {} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95d43 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:43.342122 [ 3726 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 557.23 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: (while reading column value7): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.343014 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 548.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.344298 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 548.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.344399 [ 3726 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 557.23 MiB (attempt to allocate chunk of 1.08 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB.: (while reading column value7): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_207_222_3/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 9604): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.371644 [ 3735 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 492.44 MiB (attempt to allocate chunk of 1.27 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/query_id.bin (position: 25871, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: cce7287f0407dc75e31c89c08867d64282ff6400009ecc0500): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 15. DB::ReadBuffer::next() @ 0x0000000008ef7cef 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.374458 [ 16132 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 492.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.375779 [ 16132 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 492.11 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.376568 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 492.44 MiB (attempt to allocate chunk of 1.27 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/query_id.bin (position: 25871, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: cce7287f0407dc75e31c89c08867d64282ff6400009ecc0500): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd342c2 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000003dd34ead 15. DB::ReadBuffer::next() @ 0x0000000008ef7cef 16. ./src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7be36e 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.410618 [ 3725 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 557.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.413209 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 557.15 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f5aa504 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.445592 [ 3732 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 558.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.447950 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 558.08 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:43.911846 [ 17226 ] {b0c75dc8-5dfa-4ca1-81f3-c08fd2d3c9cd} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `Y` in scope SELECT * FROM (SELECT [1, 2, 3] AS x, [4, 5, 6] AS y) ARRAY JOIN x, Y. Maybe you meant: ['y']. (UNKNOWN_IDENTIFIER) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57680) (comment: 03071_analyzer_array_join_forbid_non_existing_columns.sql) (query 2, line 3) (in query: SELECT * FROM ( SELECT [1, 2, 3] AS x, [4, 5, 6] AS y ) ARRAY JOIN x, Y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5038: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b6604 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5371: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7840 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:28:43.920825 [ 17226 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `Y` in scope SELECT * FROM (SELECT [1, 2, 3] AS x, [4, 5, 6] AS y) ARRAY JOIN x, Y. Maybe you meant: ['y']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String&&, String&&, String&&) @ 0x00000000304ccc27 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3772: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000304195a5 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5038: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b6604 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5371: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000304b7840 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5626: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb9a8 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:28:44.208129 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.209285 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.22 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.231890 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 425.62 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.234958 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 425.62 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.237979 [ 3739 ] {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_101_105_1} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.64 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.242025 [ 3739 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {28d340b3-054b-4893-b34c-fc5bc83129ec::202511_101_105_1}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 427.64 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.33 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:31: DB::MergeTreeDataPartWriterCompact::MergeTreeDataPartWriterCompact(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039ba326b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b725aa 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d13d 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.418379 [ 18403 ] {ccec9d20-5bc3-427c-b3fb-10c0f3c2759e} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Second must be integer: In scope SELECT fromUnixTimestamp64Second('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 5, line 7) (in query: SELECT fromUnixTimestamp64Second('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.428137 [ 18403 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Second must be integer: In scope SELECT fromUnixTimestamp64Second('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.482228 [ 18391 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.483428 [ 18391 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 426.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.43 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.511963 [ 3734 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.32 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/event_time_microseconds.bin (position: 39458, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 244fb0ee346db874fbf6806eaa27d49782129a000000000100): (while reading column event_time_microseconds): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationDecimalBase.cpp:63: DB::SerializationDecimalBase::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f5f4be7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 23. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.514602 [ 3734 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.32 MiB (attempt to allocate chunk of 1.02 MiB bytes), current RSS: 15.44 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/event_time_microseconds.bin (position: 39458, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: 244fb0ee346db874fbf6806eaa27d49782129a000000000100): (while reading column event_time_microseconds): (while reading from part /var/lib/clickhouse/store/905/905b2ce8-ce2c-463f-8e43-3adf9db94bd8/202511_46_71_5/ in table system.trace_log (905b2ce8-ce2c-463f-8e43-3adf9db94bd8) located on disk default of type local, from mark 0 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:83: DB::Memory>::resize(unsigned long) @ 0x000000001f9c4cca 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:188: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd399ce 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 15. ./build_docker/./src/DataTypes/Serializations/SerializationDecimalBase.cpp:63: DB::SerializationDecimalBase::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f5f4be7 16. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:525: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000039ee9946 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ee816b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 23. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 24. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.568166 [ 18403 ] {39530342-9c43-48cb-b677-98bb8515eb9a} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Milli must be integer: In scope SELECT fromUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 6, line 8) (in query: SELECT fromUnixTimestamp64Milli('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.598099 [ 18403 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Milli must be integer: In scope SELECT fromUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.639376 [ 18403 ] {3ae5b563-c997-436a-944e-8d577c0816d1} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Micro must be integer: In scope SELECT fromUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 7, line 9) (in query: SELECT fromUnixTimestamp64Micro('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.647570 [ 18403 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Micro must be integer: In scope SELECT fromUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.686164 [ 18403 ] {3cde0c08-4684-44fd-9568-b9364b7c689a} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Nano must be integer: In scope SELECT fromUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 8, line 10) (in query: SELECT fromUnixTimestamp64Nano('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.693875 [ 18403 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Nano must be integer: In scope SELECT fromUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.735610 [ 18403 ] {c965573c-757f-432d-9707-c3bef1a67442} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Second must be integer: In scope SELECT fromUnixTimestamp64Second('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 9, line 12) (in query: SELECT fromUnixTimestamp64Second('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.744815 [ 18403 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Second must be integer: In scope SELECT fromUnixTimestamp64Second('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.783631 [ 18403 ] {324a750a-cac2-4a58-91fe-c93fde50ce3a} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Milli must be integer: In scope SELECT fromUnixTimestamp64Milli('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 10, line 13) (in query: SELECT fromUnixTimestamp64Milli('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.792011 [ 18403 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Milli must be integer: In scope SELECT fromUnixTimestamp64Milli('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.886694 [ 18403 ] {24a534a7-2560-4d8a-9e0b-103786844b4a} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Micro must be integer: In scope SELECT fromUnixTimestamp64Micro('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 11, line 14) (in query: SELECT fromUnixTimestamp64Micro('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.887687 [ 3732 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.889697 [ 3732 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:44.896990 [ 18403 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Micro must be integer: In scope SELECT fromUnixTimestamp64Micro('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.938574 [ 18403 ] {f7b7927c-509c-4e15-afc2-3dac08bee0a2} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Nano must be integer: In scope SELECT fromUnixTimestamp64Nano('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57568) (comment: 01277_fromUnixTimestamp64.sql) (query 12, line 15) (in query: SELECT fromUnixTimestamp64Nano('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:44.951270 [ 18403 ] {} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Nano must be integer: In scope SELECT fromUnixTimestamp64Nano('abc', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008c9974a 4. DB::FunctionFromUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000008c95ea7 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x000000000df82d7f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000002c15311e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000002c152501 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000002c153d38 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3545: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474308 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 24. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 25. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 27. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 30. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 31. ? @ 0x00007fa150622ac3 2025.11.13 09:28:45.402274 [ 3727 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.51 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.16 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:45.404552 [ 3727 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 371.51 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.16 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:45.680369 [ 3728 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.11 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:45.682371 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.11 MiB (attempt to allocate chunk of 1.05 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:45.717585 [ 3733 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.18 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:45.720018 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 418.18 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 23. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:261: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x000000002f5ab762 24. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 28. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 29. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 30. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:46.068741 [ 3729 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.89 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:46.071050 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 424.89 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:46.085902 [ 3735 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 423.82 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:46.088022 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 423.82 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:46.154696 [ 17390 ] {e9beef06-83ca-47e5-a600-659989c821d4} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57662) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (query 4, line 15) (in query: select * apply max from data_02052_1_wide0 settings max_read_buffer_size=0, max_threads=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ad3644a 4. ./build_docker/./src/Interpreters/Context.cpp:6177: DB::Context::getReadSettings() const @ 0x000000003185804e 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:212: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x000000003c26a1d7 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:354: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c268298 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:28:46.176095 [ 17390 ] {} TCPHandler: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ad3644a 4. ./build_docker/./src/Interpreters/Context.cpp:6177: DB::Context::getReadSettings() const @ 0x000000003185804e 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:212: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x000000003c26a1d7 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:354: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c268298 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:28:46.355277 [ 3730 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 421.46 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:46.357365 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 421.46 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.38 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:46.382043 [ 16233 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:46.383057 [ 16233 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.17 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:46.410417 [ 3725 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.24 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:46.412566 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 414.24 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.37 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f69484e 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:47.083935 [ 3725 ] {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.44 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:47.086478 [ 3725 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {905b2ce8-ce2c-463f-8e43-3adf9db94bd8::202511_46_77_6}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 420.44 MiB (attempt to allocate chunk of 1.07 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc689 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f7a6970 23. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 24. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 25. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 27. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 28. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 29. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:47.103706 [ 5803 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:47.104774 [ 5803 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.10 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:47.127399 [ 3733 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.11 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:47.130272 [ 3733 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 384.11 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:47.231484 [ 19620 ] {97877872-7a93-45df-b488-1b730d8e81d9} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.67 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing MergingAggregatedTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57676) (comment: 01456_ast_optimizations_over_distributed.sql) (query 13, line 21) (in query: SELECT uniq(bitNot(number)) FROM dist;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:3159: DB::Aggregator::mergeBlocks(std::map>, std::less, std::allocator>>>>, DB::AggregatedDataVariants&, unsigned long, std::atomic&) @ 0x0000000031ce417f 11. ./build_docker/./src/Processors/Transforms/MergingAggregatedTransform.cpp:264: DB::MergingAggregatedTransform::generate() @ 0x000000003c1df686 12. ./build_docker/./src/Processors/IAccumulatingTransform.cpp:96: DB::IAccumulatingTransform::work() @ 0x000000003b182784 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 2025.11.13 09:28:47.257322 [ 19620 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 381.67 MiB (attempt to allocate chunk of 0.00 B bytes), current RSS: 15.36 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While executing MergingAggregatedTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:98: CurrentMemoryTracker::check() @ 0x000000001f62a9a5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000031c9bd17 10. ./build_docker/./src/Interpreters/Aggregator.cpp:3159: DB::Aggregator::mergeBlocks(std::map>, std::less, std::allocator>>>>, DB::AggregatedDataVariants&, unsigned long, std::atomic&) @ 0x0000000031ce417f 11. ./build_docker/./src/Processors/Transforms/MergingAggregatedTransform.cpp:264: DB::MergingAggregatedTransform::generate() @ 0x000000003c1df686 12. ./build_docker/./src/Processors/IAccumulatingTransform.cpp:96: DB::IAccumulatingTransform::work() @ 0x000000003b182784 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:262: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003b1caded 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 17. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 18. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 20. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 21. ? @ 0x00007fa150622ac3 22. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:28:47.581712 [ 17390 ] {f68b69f7-e450-4e75-9ca3-50d8ee2d7f6e} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57662) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (query 9, line 29) (in query: select * apply max from data_02052_1_wide100000000 settings max_read_buffer_size=0, max_threads=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ad3644a 4. ./build_docker/./src/Interpreters/Context.cpp:6177: DB::Context::getReadSettings() const @ 0x000000003185804e 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:212: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x000000003c26a1d7 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:354: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c268298 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:28:47.590031 [ 17390 ] {} TCPHandler: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000ad3644a 4. ./build_docker/./src/Interpreters/Context.cpp:6177: DB::Context::getReadSettings() const @ 0x000000003185804e 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:212: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x000000003c26a1d7 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:354: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000003c268298 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x0000000039c61791 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1122: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x0000000039c1bcd3 9. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:183: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x0000000039c1b235 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:301: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000003a4a1026 11. ./build_docker/./src/Planner/PlannerJoinTree.cpp:926: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000032c67164 12. ./build_docker/./src/Planner/PlannerJoinTree.cpp:2233: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000032c4893c 13. ./build_docker/./src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000032bf571e 14. ./build_docker/./src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000032be6d52 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000032bdf072 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033830022 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 18. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 19. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 21. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 24. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 25. ? @ 0x00007fa150622ac3 26. ? @ 0x00007fa1506b4850 2025.11.13 09:28:48.113821 [ 3728 ] {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 542.41 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:48.116297 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {915c40e0-d888-4224-992b-0533c5fa32c1::202511_107_169_11}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 542.41 MiB (attempt to allocate chunk of 1.01 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 27. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 29. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 31. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:48.133027 [ 3730 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 527.65 MiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_250_250_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1370): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:48.134839 [ 3730 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 527.65 MiB (attempt to allocate chunk of 1.12 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column message): (while reading from part /var/lib/clickhouse/store/15f/15f86245-aa18-4a9a-a4ff-ce8145cb7705/202511_250_250_0/ in table system.text_log (15f86245-aa18-4a9a-a4ff-ce8145cb7705) located on disk default of type local, from mark 0 with max_rows_to_read = 1370): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize_exact<>(unsigned long) @ 0x000000000cd8434d 12. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:176: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000002f7bf599 13. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:265: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f7b70b2 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 21. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 22. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 28. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 29. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 30. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 31. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:48.154636 [ 3731 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 543.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:48.156588 [ 3731 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 543.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.32 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f587dbd 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:48.266978 [ 17390 ] {72922043-bd9e-4e53-81fb-41f591f79871} executeQuery: Code: 241. DB::Exception: (total) memory limit exceeded: would use 530.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57662) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (query 12, line 36) (in query: CREATE TABLE data_02052_10_wide0 (`key` Int, `value` String) ENGINE = MergeTree ORDER BY key SETTINGS min_bytes_for_wide_part = 0, index_granularity = 59477, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 29430899, compact_parts_max_granules_to_buffer = 18, compact_parts_merge_max_bytes_to_prefetch_part = 5516234, merge_max_block_size = 4847, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 499028, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 21544425, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 97750, primary_key_compress_block_size = 11454, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = false AS SELECT number, repeat(toString(number), 5) FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 2025.11.13 09:28:48.288056 [ 17390 ] {} TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 530.20 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001f9e1ba9 13. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:107: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String, bool, unsigned long) @ 0x000000001f9e062a 14. ./build_docker/./src/IO/WriteBufferFromFile.cpp:38: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long, bool, unsigned long) @ 0x000000001fd6bc1e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107] const&, int, std::nullptr_t, int, bool const&, unsigned long const&>(std::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&, int&&, std::nullptr_t&&, int&&, bool const&, unsigned long const&) @ 0x000000002fe519ea 16. ./build_docker/./src/Disks/DiskLocal.cpp:350: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002fe35d71 17. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x000000002fe71d43 18. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:150: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000003953a619 19. ./src/Storages/MergeTree/IDataPartStorage.h:312: DB::MergeTreeDataPartWriterOnDisk::initPrimaryIndex() @ 0x0000000039bbf3cf 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:203: DB::MergeTreeDataPartWriterOnDisk::MergeTreeDataPartWriterOnDisk(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bbe953 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:106: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bdd98b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 23. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 24. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e681 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 28. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 29. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 31. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabea3f 3. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 4. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x000000003b1ca49b 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003b1c5d80 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c539a 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b1c2ee0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 9. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 10. ? @ 0x00007fa150622ac3 11. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x000000003b1c1781 5. ./build_docker/./src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x000000003aea5278 6. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 8. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 11. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 12. ? @ 0x00007fa150622ac3 13. ? @ 0x00007fa1506b4850 2025.11.13 09:28:49.219142 [ 3735 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:49.221203 [ 3735 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001facddb4 4. ./build_docker/./src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fabdd84 5. ./build_docker/./src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000001fabd60a 6. ./src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:ne190107]> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority), std::future> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority&&) @ 0x0000000039e0fc24 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000039e03e70 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039e03659 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:52: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000039e88858 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::DeserializationPrefixesCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000039b7df64 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, DB::DeserializationPrefixesCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000039b71d9d 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039f13a81 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:159: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::Block, DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr, std::shared_ptr, std::optional, bool, bool) @ 0x0000000039efbf2f 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:ne190107] const&, std::shared_ptr, std::optional, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::Block&&, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&&, std::optional&&, bool&, bool&) @ 0x0000000039f11a24 15. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000039f0440d 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039f0cef7 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003c14a598 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003c1f99ac 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000397b76f9 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x000000003979f297 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:50.448025 [ 3729 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 636.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:50.450207 [ 3729 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 636.49 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 12. ./src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x000000003dd3b19d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterOnDisk.cpp:112: DB::MergeTreeDataPartWriterOnDisk::Stream::Stream(String const&, std::shared_ptr const&, String const&, String const&, String const&, String const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&, unsigned long, DB::WriteSettings const&) @ 0x0000000039bbc85e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if>::__unique_single std::make_unique[abi:ne190107], String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&>(String&, std::shared_ptr&, String&, char const* const&, String&, String const&, std::shared_ptr&, unsigned long&, std::shared_ptr&, unsigned long const&, DB::WriteSettings&) @ 0x0000000039bfafb6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:184: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000039bf4766 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002f694936 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000002f588721 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:203: DB::MergeTreeDataPartWriterWide::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x0000000039bdee05 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:122: DB::MergeTreeDataPartWriterWide::MergeTreeDataPartWriterWide(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039bde470 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartWideWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x0000000039b8f7ca 21. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:211: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x000000003982d2ad 22. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000003a05d698 23. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:ne190107], std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>, std::vector, std::allocator>>, std::shared_ptr&, std::shared_ptr, DB::TransactionID const&, unsigned long&, bool, bool&, DB::WriteSettings, 0>(std::allocator const&, std::shared_ptr&, std::shared_ptr&, DB::NamesAndTypesList&, std::vector, std::allocator>>&&, std::vector, std::allocator>>&&, std::shared_ptr&, std::shared_ptr&&, DB::TransactionID const&, unsigned long&, bool&&, bool&, DB::WriteSettings&&) @ 0x0000000039812ad2 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000397a1924 25. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 26. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 27. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 30. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:50.497374 [ 3737 ] {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 631.85 MiB (attempt to allocate chunk of 1.98 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:50.498863 [ 16691 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 627.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:50.499352 [ 3737 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {15f86245-aa18-4a9a-a4ff-ce8145cb7705::202511_207_256_4}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 631.85 MiB (attempt to allocate chunk of 1.98 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB.: While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 11. ./src/Common/PODArray.h:152: DB::ColumnString::shrinkToFit() @ 0x00000000376e98e0 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:219: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00e51 13. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 14. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 20. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 21. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000397bd700 22. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000397d4f01 23. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a5794c7 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003984a7e2 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003984c561 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:67: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::MergeTreeBackgroundExecutor(String, unsigned long, unsigned long, StrongTypedef, StrongTypedef, std::basic_string_view>)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003985377f 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab9586 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000001facd386 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001facd13f 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:50.499972 [ 16691 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 627.30 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:50.638858 [ 16233 ] {43168285-9629-4292-aea7-5e3cd2a199aa} executeQuery: Code: 36. DB::Exception: Unexpected value of maximum unit argument (second) for function formatReadableTimeDelta, the only allowed values are: 'nanoseconds', 'microseconds', 'nanoseconds', 'seconds', 'minutes', 'hours', 'days', 'months', 'years'.: In scope SELECT formatReadableTimeDelta(-(((((1 + 60) + 3600) + 86400) + (30.5 * 86400)) + (365 * 86400)), 'second'). (BAD_ARGUMENTS) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:57810) (comment: 01521_format_readable_time_delta2.sql) (query 8, line 8) (in query: SELECT formatReadableTimeDelta(-(1 + 60 + 3600 + 86400 + 30.5 * 86400 + 365 * 86400), 'second');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type>, String const&, std::basic_string_view> const&, String&&) @ 0x000000000ee5c1f7 4. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::dispatchUnit(std::basic_string_view> const&, DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::Unit, String const&) const @ 0x000000000ee5b069 5. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee57492 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:28:50.647490 [ 16233 ] {} TCPHandler: Code: 36. DB::Exception: Unexpected value of maximum unit argument (second) for function formatReadableTimeDelta, the only allowed values are: 'nanoseconds', 'microseconds', 'nanoseconds', 'seconds', 'minutes', 'hours', 'days', 'months', 'years'.: In scope SELECT formatReadableTimeDelta(-(((((1 + 60) + 3600) + 86400) + (30.5 * 86400)) + (365 * 86400)), 'second'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type>, String const&, std::basic_string_view> const&, String&&) @ 0x000000000ee5c1f7 4. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::dispatchUnit(std::basic_string_view> const&, DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::Unit, String const&) const @ 0x000000000ee5b069 5. DB::(anonymous namespace)::FunctionFormatReadableTimeDelta::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ee57492 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008c10722 7. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15933b 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145b43 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c144992 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145a13 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3568: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000030474f2f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3839: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000030414510 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3981: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003041153a 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4305: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b04c0 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5634: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fbab9 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 28. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 29. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 31. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 2025.11.13 09:28:51.376795 [ 3728 ] {5a642d2d-8981-43c6-8ee1-d369be3bbe53::202511_1_176_35} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 625.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.29 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/5a6/5a642d2d-8981-43c6-8ee1-d369be3bbe53/202511_1_171_34/data.bin (position: 4190, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: ca9986b9b20b7b7f5328468add817b3a913400000000400000): (while reading column event_date): (while reading from part /var/lib/clickhouse/store/5a6/5a642d2d-8981-43c6-8ee1-d369be3bbe53/202511_1_171_34/ in table system.asynchronous_metric_log (5a642d2d-8981-43c6-8ee1-d369be3bbe53) located on disk default of type local, from mark 2 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c3f 12. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:111: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000003dd6fe85 13. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000003de7e2f3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:308: DB::CompressedReadBufferBase::decompressTo(char*, unsigned long, unsigned long) @ 0x000000003dd30275 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:156: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd39185 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e2825 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:51.378898 [ 3728 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5a642d2d-8981-43c6-8ee1-d369be3bbe53::202511_1_176_35}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 625.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.29 GiB, maximum: 15.30 GiB.: While reading or decompressing /var/lib/clickhouse/store/5a6/5a642d2d-8981-43c6-8ee1-d369be3bbe53/202511_1_171_34/data.bin (position: 4190, typename: DB::ReadBufferFromFilePReadWithDescriptorsCache, compressed data header: ca9986b9b20b7b7f5328468add817b3a913400000000400000): (while reading column event_date): (while reading from part /var/lib/clickhouse/store/5a6/5a642d2d-8981-43c6-8ee1-d369be3bbe53/202511_1_171_34/ in table system.asynchronous_metric_log (5a642d2d-8981-43c6-8ee1-d369be3bbe53) located on disk default of type local, from mark 2 with max_rows_to_read = 8192): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. ./src/Common/PODArray.h:118: void DB::PODArrayBase<1ul, 4096ul, Allocator, 0ul, 0ul>::resize<>(unsigned long) @ 0x000000002ea91c3f 12. ./build_docker/./src/Compression/CompressionCodecMultiple.cpp:111: DB::CompressionCodecMultiple::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x000000003dd6fe85 13. ./build_docker/./src/Compression/ICompressionCodec.cpp:119: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x000000003de7e2f3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:308: DB::CompressedReadBufferBase::decompressTo(char*, unsigned long, unsigned long) @ 0x000000003dd30275 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:156: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd39185 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000003dd3a18d 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e2825 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f589d43 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 25. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 26. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:56.504504 [ 3736 ] {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 241. DB::Exception: (total) memory limit exceeded: would use 726.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column ProfileEvents): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_116_116_0/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 799): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e00de 13. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:596: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69c395 14. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 15. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 16. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 17. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:56.506760 [ 3736 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {271130bd-537d-4a56-bc59-4f10b1bb146e::202511_98_120_2}: Code: 241. DB::Exception: (total) memory limit exceeded: would use 726.73 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.30 GiB, maximum: 15.30 GiB.: (while reading column ProfileEvents): (while reading from part /var/lib/clickhouse/store/271/271130bd-537d-4a56-bc59-4f10b1bb146e/202511_116_116_0/ in table system.query_log (271130bd-537d-4a56-bc59-4f10b1bb146e) located on disk default of type local, from mark 0 with max_rows_to_read = 799): While executing MergeTreeSequentialSource. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 7. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 9. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 10. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 11. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 12. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:220: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000002f6e00de 13. ./build_docker/./src/DataTypes/Serializations/SerializationLowCardinality.cpp:596: DB::SerializationLowCardinality::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f69c395 14. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:85: DB::SerializationNamed::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6c08ec 15. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:799: DB::SerializationTuple::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f7e935d 16. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:389: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f5b0714 17. ./build_docker/./src/DataTypes/Serializations/SerializationMap.cpp:474: DB::SerializationMap::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000002f6b7064 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:217: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000039e8ca8e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039ed6604 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039eab3b3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039ec6a7a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x0000000039f26fbf 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:194: DB::MergeTreeSequentialSource::generate() @ 0x0000000039f00924 24. ./build_docker/./src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x000000003b194bec 25. ./build_docker/./src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x000000003b19444c 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003b20ccf2 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003b20d1e8 31. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000397c2ee0 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:28:57.622501 [ 3942 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 929 entries up to offset 510432: Code: 241. DB::Exception: (total) memory limit exceeded: would use 736.90 MiB (attempt to allocate chunk of 4.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d72 10. ./build_docker/./src/Columns/ColumnString.cpp:366: COW::immutable_ptr DB::ColumnString::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x000000003770981d 11. ./src/Columns/ColumnsCommon.h:136: DB::ColumnString::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x00000000376e1f2f 12. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:47: DB::permuteBlockIfNeeded(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039829bfb 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:189: DB::MergeTreeDataPartWriterCompact::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039ba572d 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:396: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000003a05e6b2 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:764: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039c8e9a3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039c83837 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a5738fd 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003be3a769 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107]>(std::__function::__policy_storage const*) @ 0x000000003bb0e6d9 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000003bb0e1f6 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x000000003bb0d60b 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x000000003b1fda8d 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003b1c80b4 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003b1c6d16 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x000000003b218b5a 26. ./build_docker/./src/Interpreters/SystemLog.cpp:597: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000033361181 27. ./build_docker/./src/Interpreters/SystemLog.cpp:524: DB::SystemLog::savingThreadFunction() @ 0x000000003335e7be 28. ./build_docker/./src/Common/SystemLogBase.cpp:281: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001fba3381 29. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001fba31bf 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 31. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:29:03.541880 [ 16887 ] {d6aa7388-b70a-4e8d-944e-94b6e68bdee6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45466) (comment: 02473_multistep_prewhere.sh) (in query: DROP DATABASE IF EXISTS test_wpzi09x4 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:29:03.550069 [ 16887 ] {d6aa7388-b70a-4e8d-944e-94b6e68bdee6} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:29:03.596615 [ 18728 ] {c80fbb7a-2621-4f24-8ca6-62c269d81f8c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:45478) (comment: 02473_multistep_prewhere.sh) (in query: DROP DATABASE IF EXISTS test_wpzi09x4 SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:29:03.604826 [ 18728 ] {c80fbb7a-2621-4f24-8ca6-62c269d81f8c} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:29:11.381070 [ 18797 ] {} ExternalDictionariesLoader: Could not load external dictionary '1119b8f4-92d2-4582-bb09-e8200cde5e0e', next update is scheduled at 2025-11-13 09:30:13: Code: 60. DB::Exception: Unknown table expression identifier 'test_9hufdy9z.dict_data' in scope SELECT key, v0, v1, v2, v3, v4 FROM test_9hufdy9z.dict_data. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000002702efa8 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x000000002702e915 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0a87 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:29:33.151735 [ 4170 ] {ad3d141f-76e3-400a-8a75-c6b62c6a7790} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39840) (comment: 03261_pr_semi_anti_join.sql) (in query: DROP DATABASE IF EXISTS test_56bc3cpn SYNC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:29:33.159033 [ 4170 ] {ad3d141f-76e3-400a-8a75-c6b62c6a7790} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x0000000008c36bc4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:615: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x0000000031ae759c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000032a74792 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000032a65f10 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a629b2 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:30:16.778529 [ 10189 ] {} ExternalDictionariesLoader: Could not load external dictionary '1119b8f4-92d2-4582-bb09-e8200cde5e0e', next update is scheduled at 2025-11-13 09:38:12: Code: 60. DB::Exception: Unknown table expression identifier 'test_9hufdy9z.dict_data' in scope SELECT key, v0, v1, v2, v3, v4 FROM test_9hufdy9z.dict_data. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a341cad 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4373: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000304b472c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5623: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000303fb461 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:178: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000303f7bc6 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000303f6359 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003056ec59 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000032bdc46f 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000032bd60ce 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:ne190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000032bdfbd2 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:293: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl[abi:ne190107]> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000032bdf753 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000032ab9d0f 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x000000003382f7b0 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:182: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000002702efa8 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:116: DB::ClickHouseDictionarySource::loadAll() @ 0x000000002702e915 18. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::loadData() @ 0x00000000282f0a87 19. DB::HashedDictionary<(DB::DictionaryKeyType)0, false, true>::HashedDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::HashedDictionaryConfiguration const&, std::shared_ptr) @ 0x00000000282ef77c 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::registerDictionaryHashed(DB::DictionaryFactory&)::$_4::operator()(String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, DB::DictionaryKeyType, bool) const @ 0x0000000027a917c6 21. ./build_docker/./src/Dictionaries/registerHashedDictionary.cpp:125: std::unique_ptr> std::__function::__policy_invoker> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>::__call_impl[abi:ne190107]> (String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::shared_ptr, bool)>>(std::__function::__policy_storage const*, String const&, DB::DictionaryStructure const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::shared_ptr&&, bool) @ 0x0000000027a8da5f 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002c121711 23. ./build_docker/./src/Dictionaries/DictionaryFactory.cpp:58: DB::DictionaryFactory::create(String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, bool) const @ 0x000000002c11f8fd 24. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000328a1260 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000328cec0a 26. ./build_docker/./src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000328cad31 27. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'()::operator()() @ 0x00000000328d96c9 28. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl), DB::ExternalLoader::LoadingDispatcher*, String&, unsigned long&, bool&, unsigned long&, bool, std::shared_ptr>(void (DB::ExternalLoader::LoadingDispatcher::*&&)(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr), DB::ExternalLoader::LoadingDispatcher*&&, String&, unsigned long&, bool&, unsigned long&, bool&&, std::shared_ptr&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000328d915f 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 30. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 31. ? @ 0x00007fa150622ac3 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:31:34.292703 [ 18728 ] {f6faec3e-8548-41be-9167-44ac38221348} executeQuery: Code: 60. DB::Exception: Table test_13.test_replicated_limit does not exist. Maybe you meant test_13.test_replicated?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39626) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 2) (in query: DROP TABLE test_replicated_limit SYNC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:31:34.315195 [ 18728 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.test_replicated_limit does not exist. Maybe you meant test_13.test_replicated?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:35:24.790613 [ 18728 ] {89a6eb10-df19-4c62-b089-32f1a0d15cba} executeQuery: Code: 60. DB::Exception: Table test_13.test_replicated_limit does not exist. Maybe you meant test_13.test_replicated?. (UNKNOWN_TABLE) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:39488) (comment: 02676_optimize_old_parts_replicated.sh) (query 1, line 2) (in query: DROP TABLE test_replicated_limit;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:35:24.805934 [ 18728 ] {} TCPHandler: Code: 60. DB::Exception: Table test_13.test_replicated_limit does not exist. Maybe you meant test_13.test_replicated?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008e3c91f 4. ./build_docker/./src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x000000002faa70a5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:449: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000031adaf15 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1033: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x0000000031af4bf4 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000032a6777a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000032a658ff 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000032a62759 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000032a61fb3 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000338227b9 13. ./build_docker/./src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x000000003aea48a1 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 2025.11.13 09:35:53.641728 [ 17388 ] {812b862a-7447-4fd5-83c1-b4ed20730252} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:55774) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_mdjr5gj0.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:35:53.672334 [ 17388 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:35:53.988040 [ 3671 ] {} test_mdjr5gj0.dist_in.DistributedInsertQueue.default: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000039455686 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:216: DB::DistributedAsyncInsertDirectoryQueue::run() @ 0x000000003944fc6e 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, String const&, std::shared_ptr, DB::ActionBlocker&, DB::BackgroundSchedulePool&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039468d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:56.106372 [ 18728 ] {596a6f48-ba63-4122-85eb-2fe393671e54} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60028) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_mdjr5gj0.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:35:56.127820 [ 3680 ] {} test_mdjr5gj0.dist_in.DistributedInsertQueue.default: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000039455686 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:216: DB::DistributedAsyncInsertDirectoryQueue::run() @ 0x000000003944fc6e 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, String const&, std::shared_ptr, DB::ActionBlocker&, DB::BackgroundSchedulePool&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039468d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:56.133409 [ 18728 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:35:58.220454 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.221506 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.243049 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.244474 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.34 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.255713 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.60 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.256825 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.60 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.279512 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.60 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.280607 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.60 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.302239 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.60 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.303481 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.60 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.317942 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.77 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.319183 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.77 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.367085 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.85 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.368145 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.85 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.375115 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.85 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.376142 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.85 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.381192 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.85 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.382156 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.85 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.385634 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.85 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.386946 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 383.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.85 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.409826 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.80 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.411185 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 385.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.80 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.428148 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.80 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.429384 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 387.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.80 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.465057 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.67 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.466250 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.67 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.482437 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.67 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.483532 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.67 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.493334 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.67 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.494406 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 389.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.67 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.581666 [ 17388 ] {} TCPHandler: TCPHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:58.582897 [ 17388 ] {} ServerErrorHandler: Code: 241. DB::Exception: (total) memory limit exceeded: would use 399.40 MiB (attempt to allocate chunk of 1.00 MiB bytes), current RSS: 15.31 GiB, maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001f6254ad 9. ./src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000001f9660aa 10. ./src/IO/BufferWithOwnMemory.h:47: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, unsigned long) @ 0x000000001fcabf39 11. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:130: DB::ReadBufferFromPocoSocketBase::ReadBufferFromPocoSocketBase(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000001fcac506 12. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:19: DB::ReadBufferFromPocoSocketChunked::ReadBufferFromPocoSocketChunked(Poco::Net::Socket&, StrongTypedef const&, unsigned long) @ 0x000000003aac2552 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::runImpl() @ 0x000000003aea0b6b 14. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 16. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 19. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 20. ? @ 0x00007fa150622ac3 21. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:59.890081 [ 17388 ] {87a3d0ee-e9ef-472b-b64f-48e4070a1a8b} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60424) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_mdjr5gj0.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:35:59.911466 [ 3676 ] {} test_mdjr5gj0.dist_in.DistributedInsertQueue.default: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000039455686 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:216: DB::DistributedAsyncInsertDirectoryQueue::run() @ 0x000000003944fc6e 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, String const&, std::shared_ptr, DB::ActionBlocker&, DB::BackgroundSchedulePool&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039468d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:35:59.919173 [ 17388 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:36:06.846051 [ 17388 ] {b49cbf8a-dcc9-476a-a290-276196974dc2} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:56508) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_mdjr5gj0.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:36:06.866722 [ 3676 ] {} test_mdjr5gj0.dist_in.DistributedInsertQueue.default: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000039455686 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:216: DB::DistributedAsyncInsertDirectoryQueue::run() @ 0x000000003944fc6e 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, String const&, std::shared_ptr, DB::ActionBlocker&, DB::BackgroundSchedulePool&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039468d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:36:06.872503 [ 17388 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:36:20.199059 [ 17388 ] {7860d607-d706-40f4-b7f8-a1dc5c7f9ff5} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:50910) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_mdjr5gj0.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:36:20.218852 [ 3676 ] {} test_mdjr5gj0.dist_in.DistributedInsertQueue.default: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000039455686 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:216: DB::DistributedAsyncInsertDirectoryQueue::run() @ 0x000000003944fc6e 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, String const&, std::shared_ptr, DB::ActionBlocker&, DB::BackgroundSchedulePool&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039468d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:36:20.224192 [ 17388 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:36:46.403511 [ 17388 ] {e7313bd8-adf8-4656-a372-e56f4449705a} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:52774) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_mdjr5gj0.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:36:46.423885 [ 3676 ] {} test_mdjr5gj0.dist_in.DistributedInsertQueue.default: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000039455686 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:216: DB::DistributedAsyncInsertDirectoryQueue::run() @ 0x000000003944fc6e 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, String const&, std::shared_ptr, DB::ActionBlocker&, DB::BackgroundSchedulePool&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039468d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:36:46.430192 [ 17388 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:36:59.013078 [ 73465 ] {ab64f6e9-032a-4ae2-9e4d-715940d7aa82} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60290.224094 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:60404) (query 1, line 2) (in query: SELECT sleepEachRow(( SELECT maxOrDefault(300 - elapsed) + 1 FROM system.processes WHERE query NOT LIKE '%FROM system.processes%' AND elapsed < 300 ) / 300) FROM numbers(300) FORMAT Null SETTINGS function_sleep_max_microseconds_per_block = 0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 2025.11.13 09:36:59.031837 [ 73465 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60290.224094 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x000000002f26b8cd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x000000002f268a63 5. ./build_docker/./src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000032f748b0 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x000000003b1c6167 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003b1c5861 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000003b20a7f7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 10. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 11. ? @ 0x00007fa150622ac3 12. ? @ 0x00007fa1506b4850 Job's origin stack trace: 0. ./build_docker/./src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000001f8ae4e7 1. ./build_docker/./src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000001faaf9dc 2. ./build_docker/./src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001fab5e7f 3. ./build_docker/./src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000001fab6bf4 4. ./src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003b20633d 5. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003b2074eb 6. ./build_docker/./src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x000000003aed45bf 7. ./build_docker/./src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x000000003aea4bf6 8. ./build_docker/./src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x000000003af0c23c 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 10. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 13. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 14. ? @ 0x00007fa150622ac3 15. ? @ 0x00007fa1506b4850 2025.11.13 09:37:01.821129 [ 73465 ] {e345250b-4693-4847-9e4c-3f0896a22a76} executeQuery: Code: 521. DB::ErrnoException: Cannot rename /var/lib/clickhouse/metadata/test.sql.tmp to /var/lib/clickhouse/metadata/test.sql because the second path already exists: , errno: 17, strerror: File exists. (ATOMIC_RENAME_FAIL) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:47090) (in query: CREATE DATABASE IF NOT EXISTS test ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000002f8d93b2 4. ./build_docker/./src/Common/atomicRename.cpp:94: DB::renameat2(String const&, String const&, int) @ 0x000000002f8d8d11 5. ./build_docker/./src/Common/atomicRename.cpp:227: DB::renameNoReplace(String const&, String const&) @ 0x000000002f8d7c84 6. ./build_docker/./src/Disks/DiskLocal.cpp:318: DB::DiskLocal::moveFile(String const&, String const&) @ 0x000000002fe312ad 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:395: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b9d10 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 2025.11.13 09:37:01.830282 [ 73465 ] {e345250b-4693-4847-9e4c-3f0896a22a76} DynamicQueryHandler: Code: 521. DB::ErrnoException: Cannot rename /var/lib/clickhouse/metadata/test.sql.tmp to /var/lib/clickhouse/metadata/test.sql because the second path already exists: , errno: 17, strerror: File exists. (ATOMIC_RENAME_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000002f8d93b2 4. ./build_docker/./src/Common/atomicRename.cpp:94: DB::renameat2(String const&, String const&, int) @ 0x000000002f8d8d11 5. ./build_docker/./src/Common/atomicRename.cpp:227: DB::renameNoReplace(String const&, String const&) @ 0x000000002f8d7c84 6. ./build_docker/./src/Disks/DiskLocal.cpp:318: DB::DiskLocal::moveFile(String const&, String const&) @ 0x000000002fe312ad 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:395: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000329b9d10 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2354: DB::InterpreterCreateQuery::execute() @ 0x0000000032a2be40 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000033832045 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x000000003384034e 11. ./build_docker/./src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003acdfb70 12. ./build_docker/./src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003aceb3e1 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x000000003af3302a 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000004155cf60 15. ./build_docker/./base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000004155de92 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x0000000041442a35 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:45: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000004143f82e 18. ./base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000004143c3b1 19. ? @ 0x00007fa150622ac3 20. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:37:17.221511 [ 17388 ] {bf36b94f-5e11-4f70-bf5d-b5e869bef876} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED) (version 25.3.8.10072.altinitytest (altinity build)) (from [::1]:37514) (comment: 03030_system_flush_distributed_settings.sql) (query 14, line 17) (in query: INSERT INTO test_mdjr5gj0.ephemeral (key, value) VALUES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:37:17.253288 [ 3669 ] {} test_mdjr5gj0.dist_in.DistributedInsertQueue.default: Code: 241. DB::Exception: Received from localhost:9000. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). Stack trace: 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 : While sending a batch of 1 files, files: /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1//1.bin. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. ./src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001f97a257 3. ./build_docker/./src/Client/Connection.cpp:1444: DB::Connection::receiveException() const @ 0x000000003aa8ef4b 4. ./build_docker/./src/Client/Connection.cpp:1273: DB::Connection::receivePacket() @ 0x000000003aaad03b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:134: DB::RemoteInserter::onFinish() @ 0x0000000039483577 6. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:286: DB::DistributedAsyncInsertBatch::sendBatch(DB::SettingsChanges const&) @ 0x000000003947b77e 7. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertBatch.cpp:101: DB::DistributedAsyncInsertBatch::send(DB::SettingsChanges const&, bool) @ 0x0000000039471f36 8. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:552: DB::DistributedAsyncInsertDirectoryQueue::processFilesWithBatching(bool, DB::SettingsChanges const&) @ 0x0000000039455686 9. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:388: DB::DistributedAsyncInsertDirectoryQueue::processFiles(bool, DB::SettingsChanges const&) @ 0x000000003944ecd8 10. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:216: DB::DistributedAsyncInsertDirectoryQueue::run() @ 0x000000003944fc6e 11. ./build_docker/./src/Storages/Distributed/DistributedAsyncInsertDirectoryQueue.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:ne190107] const&, String const&, std::shared_ptr, DB::ActionBlocker&, DB::BackgroundSchedulePool&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000039468d1f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002ead9e6d 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000002eae4d3c 14. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:ne190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002eae6eef 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001fab1e67 16. ./contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:ne190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001fac57c4 17. ? @ 0x00007fa150622ac3 18. ? @ 0x00007fa1506b4850 (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:37:17.261140 [ 17388 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 112.01 MiB (attempt to allocate chunk of 32.00 MiB bytes), maximum: 100.00 MiB.: while executing 'FUNCTION CAST(__table1.value :: 0, 'String'_String :: 2) -> CAST(__table1.value, 'String'_String) String : 1': while pushing to view test_mdjr5gj0.mv (eef15fa9-ddf6-42e9-a77c-084661fe0699). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000001f8546bc 4. ./build_docker/./src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f850a5e 5. ./build_docker/./src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001f84fa68 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000001f62a671 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:104: CurrentMemoryTracker::alloc(long) @ 0x000000001f62a9fd 8. ./build_docker/./src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001f626084 9. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000008c21d11 10. DB::WriteBufferFromVectorImpl, 63ul, 64ul>>::nextImpl() @ 0x0000000008c37a48 11. DB::WriteBuffer::next() @ 0x0000000008c37ea1 12. ./src/IO/WriteBuffer.h:85: DB::WriteBuffer::write(char const*, unsigned long) @ 0x000000001f9de57a 13. void DB::detail::writeUIntTextFallback(int, DB::WriteBuffer&) @ 0x0000000008cef689 14. ./src/IO/WriteIntText.h:43: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeString, DB::detail::NameToString, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000002cdf839f 15. ./src/Functions/FunctionsConversion.h:2472: bool DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)::operator(), DB::DataTypeString>>(auto const&, DB::detail::BehaviourOnErrorFromString) const @ 0x000000002cde76f9 16. ./src/Core/callOnTypeIndex.h:261: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a7fbb 17. ./src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c9a6782 18. ./build_docker/./src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c15925b 19. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 20. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14ac1d 21. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 22. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c150f3f 23. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:ne190107], std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000002c3b71c9 24. DB::detail::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000002c31b8b8 25. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c145cc7 26. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14adb5 27. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000002c14fe86 28. ./build_docker/./src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000031b6d645 29. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003bb0f734 30. ./src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000027006804 31. ./build_docker/./src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000003b18cda1 2025.11.13 09:37:34.985334 [ 2992 ] {} Application: Closed all listening sockets. Waiting for 40 outstanding connections. 2025.11.13 09:37:39.892073 [ 2992 ] {} Application: Closed connections. But 40 remain. Tip: To increase wait time add to config: 60 2025.11.13 09:37:39.893210 [ 2992 ] {} Application: Will shutdown forcefully. 2025.11.13 09:37:43.975989 [ 73560 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.11.13 09:37:52.908138 [ 73560 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.11.13 09:37:52.916181 [ 73560 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.11.13 09:37:52.916264 [ 73560 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.11.13 09:37:52.968273 [ 74193 ] {} RaftInstance: Election timeout, initiate leader election 2025.11.13 09:37:53.532493 [ 73560 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.11.13 09:37:53.536801 [ 73560 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.11.13 09:37:53.538262 [ 73560 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.11.13 09:38:06.237799 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_p37oecw7.sql.tmp 2025.11.13 09:38:06.237966 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_lhtdbyb9.sql.tmp 2025.11.13 09:38:06.238122 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_j0huw7bs.sql.tmp 2025.11.13 09:38:06.238259 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_3ys3oijd.sql.tmp 2025.11.13 09:38:06.238362 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_a2tmflej.sql.tmp 2025.11.13 09:38:06.238522 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_t0pxrcw6.sql.tmp 2025.11.13 09:38:06.238599 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_c6r6ezw7.sql.tmp 2025.11.13 09:38:06.238699 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_ly7jgxpi.sql.tmp 2025.11.13 09:38:06.238814 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_jgiav80v.sql.tmp 2025.11.13 09:38:06.238892 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_nnzi2fl8.sql.tmp 2025.11.13 09:38:06.239023 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_rnqm9j78.sql.tmp 2025.11.13 09:38:06.239112 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_qbcxhg3l.sql.tmp 2025.11.13 09:38:06.239223 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_ufsvv1ll.sql.tmp 2025.11.13 09:38:06.239364 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_hc7x5sam.sql.tmp 2025.11.13 09:38:06.239483 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_ygbuzznl.sql.tmp 2025.11.13 09:38:06.239591 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_hf83yy4o.sql.tmp 2025.11.13 09:38:06.239669 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_lq6dkgyd.sql.tmp 2025.11.13 09:38:06.239744 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_0kuh2kco.sql.tmp 2025.11.13 09:38:06.239840 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_z4jj4v2a.sql.tmp 2025.11.13 09:38:06.239914 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_phlgxtqh.sql.tmp 2025.11.13 09:38:06.239989 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_sc08gklz.sql.tmp 2025.11.13 09:38:06.240091 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_ml0foygi.sql.tmp 2025.11.13 09:38:06.240210 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_ma4tjuhd.sql.tmp 2025.11.13 09:38:06.240290 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_5rk6jjwq.sql.tmp 2025.11.13 09:38:06.240389 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_83c3fipq.sql.tmp 2025.11.13 09:38:06.240470 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_gm4cdufi.sql.tmp 2025.11.13 09:38:06.240544 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_xijtjiec.sql.tmp 2025.11.13 09:38:06.240619 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_d6ys00nw.sql.tmp 2025.11.13 09:38:06.240711 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_636b6p6t.sql.tmp 2025.11.13 09:38:06.240785 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_r2gh2i2r.sql.tmp 2025.11.13 09:38:06.240859 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_6xk0re8w.sql.tmp 2025.11.13 09:38:06.240943 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_46zxskrk.sql.tmp 2025.11.13 09:38:06.241045 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_l4r7ov8g.sql.tmp 2025.11.13 09:38:06.241121 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_4fnfwl0g.sql.tmp 2025.11.13 09:38:06.241207 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_e6kke5zk.sql.tmp 2025.11.13 09:38:06.241290 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_ja5qfjz4.sql.tmp 2025.11.13 09:38:06.241363 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_fgdiajnd.sql.tmp 2025.11.13 09:38:06.241460 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_lfg1045f.sql.tmp 2025.11.13 09:38:06.241571 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_bfhvijbc.sql.tmp 2025.11.13 09:38:06.241666 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_nyls1hb9.sql.tmp 2025.11.13 09:38:06.241740 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_v7ag4hul.sql.tmp 2025.11.13 09:38:06.241824 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_p7f4ngm2.sql.tmp 2025.11.13 09:38:06.241910 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_inawd769.sql.tmp 2025.11.13 09:38:06.241985 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_yzpprsss.sql.tmp 2025.11.13 09:38:06.242081 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_vdcgeggp.sql.tmp 2025.11.13 09:38:06.242177 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_vsvn8pn0.sql.tmp 2025.11.13 09:38:06.242267 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_7uwxf69v.sql.tmp 2025.11.13 09:38:06.242341 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_zma1ptep.sql.tmp 2025.11.13 09:38:06.242414 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_rf7ytpmm.sql.tmp 2025.11.13 09:38:06.242488 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_lvxwmkoq.sql.tmp 2025.11.13 09:38:06.242561 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_68vfzpt2.sql.tmp 2025.11.13 09:38:06.242648 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_o6iql7d1.sql.tmp 2025.11.13 09:38:06.242723 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_bakffoxy.sql.tmp 2025.11.13 09:38:06.242797 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_b56g6bji.sql.tmp 2025.11.13 09:38:06.242909 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_boqf24sn.sql.tmp 2025.11.13 09:38:06.242985 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_3liluntg.sql.tmp 2025.11.13 09:38:06.243059 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_0pwr7qgv.sql.tmp 2025.11.13 09:38:06.243131 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_f4xkgp38.sql.tmp 2025.11.13 09:38:06.243223 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_pmuv9up8.sql.tmp 2025.11.13 09:38:06.243300 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_59rwwkg0.sql.tmp 2025.11.13 09:38:06.243375 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_szeun1b3.sql.tmp 2025.11.13 09:38:06.243470 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_9sdwchjv.sql.tmp 2025.11.13 09:38:06.243559 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_q3w4sdwb.sql.tmp 2025.11.13 09:38:06.243634 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_mp4m6tfv.sql.tmp 2025.11.13 09:38:06.243708 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_iv72o8ld.sql.tmp 2025.11.13 09:38:06.243802 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_ko6mi56a.sql.tmp 2025.11.13 09:38:06.243877 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_ruunlmes.sql.tmp 2025.11.13 09:38:06.243956 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_2dot55i8.sql.tmp 2025.11.13 09:38:06.244047 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_pkf5si6e.sql.tmp 2025.11.13 09:38:06.244207 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_pqe21lpm.sql.tmp 2025.11.13 09:38:06.244294 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_0recnhnb.sql.tmp 2025.11.13 09:38:06.244391 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_8j6064e2.sql.tmp 2025.11.13 09:38:06.244472 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_zqf4b8bv.sql.tmp 2025.11.13 09:38:06.244546 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_wt5c06vk.sql.tmp 2025.11.13 09:38:06.244659 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_efk02tzc.sql.tmp 2025.11.13 09:38:06.244761 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_f1z1clwi.sql.tmp 2025.11.13 09:38:06.244835 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_seg4dn2o.sql.tmp 2025.11.13 09:38:06.244914 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_nvusoaku.sql.tmp 2025.11.13 09:38:06.245010 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_cbmp4zds.sql.tmp 2025.11.13 09:38:06.245126 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_9u3gy83q.sql.tmp 2025.11.13 09:38:06.245308 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_cxgehd5h.sql.tmp 2025.11.13 09:38:06.245399 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_z3wux07e.sql.tmp 2025.11.13 09:38:06.245474 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_c438so16.sql.tmp 2025.11.13 09:38:06.245572 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_f0ynyh8n.sql.tmp 2025.11.13 09:38:06.245654 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_hw7eabm2.sql.tmp 2025.11.13 09:38:06.245729 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_f52fmsi6.sql.tmp 2025.11.13 09:38:06.245803 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_xjb2c6f2.sql.tmp 2025.11.13 09:38:06.245878 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_i4j9td4i.sql.tmp 2025.11.13 09:38:06.245969 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_mo9wu477.sql.tmp 2025.11.13 09:38:06.246062 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_2u1s0x1z.sql.tmp 2025.11.13 09:38:06.246147 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_2lorwhgw.sql.tmp 2025.11.13 09:38:06.246248 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_4tftry6x.sql.tmp 2025.11.13 09:38:06.246386 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_1wlyz6sf.sql.tmp 2025.11.13 09:38:06.246501 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test.sql.tmp 2025.11.13 09:38:06.246581 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_0cf2c528.sql.tmp 2025.11.13 09:38:06.246654 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_w6i6afwf.sql.tmp 2025.11.13 09:38:06.246749 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_3ckik4hr.sql.tmp 2025.11.13 09:38:06.246824 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_ves2pyze.sql.tmp 2025.11.13 09:38:06.246914 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_4u8noqek.sql.tmp 2025.11.13 09:38:06.246987 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_mvdww6ru.sql.tmp 2025.11.13 09:38:06.247076 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_zay2ewot.sql.tmp 2025.11.13 09:38:06.247166 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_l14bkf3e.sql.tmp 2025.11.13 09:38:06.247260 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_g88huq29.sql.tmp 2025.11.13 09:38:06.247335 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_2sw0xrei.sql.tmp 2025.11.13 09:38:06.247441 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_of7vjovl.sql.tmp 2025.11.13 09:38:06.247535 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_tlfxgc2u.sql.tmp 2025.11.13 09:38:06.247609 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_jg4rp9ss.sql.tmp 2025.11.13 09:38:06.247712 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_jvp43sb0.sql.tmp 2025.11.13 09:38:06.247829 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_8h9cu5en.sql.tmp 2025.11.13 09:38:06.247925 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_ii1dfhlr.sql.tmp 2025.11.13 09:38:06.248053 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_sdjjmwzb.sql.tmp 2025.11.13 09:38:06.248166 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_tp1rcbrv.sql.tmp 2025.11.13 09:38:06.248261 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_3ib6w025.sql.tmp 2025.11.13 09:38:06.248337 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_o93nap1a.sql.tmp 2025.11.13 09:38:06.248435 [ 73560 ] {} loadMetadata: Removing temporary file metadata/test_6vslx7ga.sql.tmp 2025.11.13 09:38:06.252095 [ 73560 ] {} Context: Server has databases (for example `test_11_broken_tables`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.11.13 09:38:06.847130 [ 73560 ] {} TablesLoader: Tables test_mdjr5gj0.dist_in, test_f63tw0eg.dist depend on default.key, but seems like that does not exist. Will ignore it and try to load existing tables 2025.11.13 09:38:06.847311 [ 73560 ] {} TablesLoader: Tables test_9hufdy9z.dict_sharded_multi depend on test_9hufdy9z.dict_data, but seems like that does not exist. Will ignore it and try to load existing tables 2025.11.13 09:38:06.847703 [ 73560 ] {} TablesLoader: Tables test_7.dist_01757 depend on default.dummy, but seems like that does not exist. Will ignore it and try to load existing tables 2025.11.13 09:38:07.017146 [ 74458 ] {} test_mdjr5gj0.dist_in.DistributedInsertQueue.default: Unexpected file /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1/current_batch.txt in /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1/ 2025.11.13 09:38:07.558493 [ 74161 ] {} test_mdjr5gj0.dist_in.DistributedInsertQueue.default: File /var/lib/clickhouse/store/7db/7db04174-0050-401d-847d-9413b0bf681d/shard1_replica1/1.bin does not exist, likely due to current_batch.txt processing 2025.11.13 09:38:07.656817 [ 74437 ] {} DDLWorker(test_b6rkqk5l): Replica seems to be lost: our_log_ptr=5, max_log_ptr=5, local_digest=12282629820290064824, zk_digest=3419915760309660884 2025.11.13 09:38:07.658331 [ 74437 ] {} DatabaseReplicated (test_b6rkqk5l): Will recover replica with staled log pointer 5 from log pointer 5 2025.11.13 09:38:14.766288 [ 73560 ] {} Application: Closed all listening sockets. Waiting for 1 outstanding connections. 2025.11.13 09:38:19.672164 [ 73560 ] {} Application: Closed connections. But 1 remain. Tip: To increase wait time add to config: 60 2025.11.13 09:38:19.672375 [ 73560 ] {} Application: Will shutdown forcefully. 2025.11.13 09:38:30.551809 [ 74670 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.11.13 09:38:32.319770 [ 74670 ] {} DiskLocal: Disk disk1_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk1_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007fdcc3223d90 27. ? @ 0x00007fdcc3223e40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:38:32.320360 [ 74670 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.11.13 09:38:32.320567 [ 74670 ] {} DiskLocal: Disk disk2_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk2_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007fdcc3223d90 27. ? @ 0x00007fdcc3223e40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:38:32.320882 [ 74670 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.11.13 09:38:32.321045 [ 74670 ] {} DiskLocal: Disk disk3_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk3_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007fdcc3223d90 27. ? @ 0x00007fdcc3223e40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:38:32.321346 [ 74670 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.11.13 09:38:32.321502 [ 74670 ] {} DiskLocal: Disk disk4_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk4_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007fdcc3223d90 27. ? @ 0x00007fdcc3223e40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:38:51.358077 [ 75365 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.11.13 09:38:53.141888 [ 75365 ] {} DiskLocal: Disk disk1_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk1_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007f5458220d90 27. ? @ 0x00007f5458220e40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:38:53.142533 [ 75365 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.11.13 09:38:53.142716 [ 75365 ] {} DiskLocal: Disk disk2_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk2_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007f5458220d90 27. ? @ 0x00007f5458220e40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:38:53.143023 [ 75365 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.11.13 09:38:53.143170 [ 75365 ] {} DiskLocal: Disk disk3_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk3_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007f5458220d90 27. ? @ 0x00007f5458220e40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:38:53.143456 [ 75365 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.11.13 09:38:53.143593 [ 75365 ] {} DiskLocal: Disk disk4_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk4_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007f5458220d90 27. ? @ 0x00007f5458220e40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:39:10.933859 [ 76053 ] {} DiskLocal: Cannot gain read access of the disk directory: disk1_02961/ 2025.11.13 09:39:13.009111 [ 76053 ] {} DiskLocal: Disk disk1_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk1_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007f7bf838cd90 27. ? @ 0x00007f7bf838ce40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:39:13.009664 [ 76053 ] {} DiskLocal: Cannot gain read access of the disk directory: disk2_02961/ 2025.11.13 09:39:13.009845 [ 76053 ] {} DiskLocal: Disk disk2_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk2_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007f7bf838cd90 27. ? @ 0x00007f7bf838ce40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:39:13.010155 [ 76053 ] {} DiskLocal: Cannot gain read access of the disk directory: disk3_02961/ 2025.11.13 09:39:13.010315 [ 76053 ] {} DiskLocal: Disk disk3_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk3_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007f7bf838cd90 27. ? @ 0x00007f7bf838ce40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build)) 2025.11.13 09:39:13.010600 [ 76053 ] {} DiskLocal: Cannot gain read access of the disk directory: disk4_02961/ 2025.11.13 09:39:13.010738 [ 76053 ] {} DiskLocal: Disk disk4_02961 is marked as broken during startup: Code: 481. DB::ErrnoException: Cannot check read access to file: disk4_02961/: , errno: 2, strerror: No such file or directory. (PATH_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000004131c8e6 1. ./build_docker/./src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001f6ddf52 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008c135df 3. ./src/Common/Exception.h:223: DB::ErrnoException::ErrnoException(int, int, FormatStringHelperImpl::type>, String const&) @ 0x000000001f92026f 4. ./src/Common/Exception.h:238: void DB::ErrnoException::throwFromPath(int, String const&, FormatStringHelperImpl::type>, String const&) @ 0x000000001f91f9c8 5. ./build_docker/./src/Common/filesystemHelpers.cpp:320: FS::canRead(String const&) @ 0x000000001f936bd7 6. ./build_docker/./src/Disks/DiskLocal.cpp:680: DB::DiskLocal::setup() @ 0x000000002fe4bef7 7. ./build_docker/./src/Disks/DiskLocal.cpp:752: DB::DiskLocal::startupImpl(std::shared_ptr) @ 0x000000002fe4eae6 8. ./build_docker/./src/Disks/IDisk.cpp:212: DB::IDisk::startup(std::shared_ptr, bool) @ 0x000000002fe6c9f7 9. ./build_docker/./src/Disks/DiskLocal.cpp:803: std::shared_ptr std::__function::__policy_invoker (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>::__call_impl[abi:ne190107] (String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::map, std::less, std::allocator>>> const&, bool, bool)>>(std::__function::__policy_storage const*, String const&, Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr&&, std::map, std::less, std::allocator>>> const&, bool, bool) @ 0x000000002fe51067 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000002fe2102a 11. ./build_docker/./src/Disks/DiskSelector.cpp:55: DB::DiskSelector::initialize(Poco::Util::AbstractConfiguration const&, String const&, std::shared_ptr, std::function) @ 0x000000002fea6df0 12. ./build_docker/./src/Interpreters/Context.cpp:5044: DB::Context::getDiskSelector(std::lock_guard&) const @ 0x0000000031834676 13. ./build_docker/./src/Interpreters/Context.cpp:5028: DB::Context::getDisksMap(std::lock_guard&) const @ 0x0000000031835663 14. ./build_docker/./src/Interpreters/Context.cpp:5023: DB::Context::getDatabaseDisk() const @ 0x00000000317ab48f 15. ./build_docker/./src/Databases/DatabasesCommon.cpp:349: DB::DatabaseWithOwnTablesBase::DatabaseWithOwnTablesBase(String const&, String const&, std::shared_ptr) @ 0x000000002fa8256f 16. ./build_docker/./src/Databases/DatabaseMemory.cpp:24: DB::DatabaseMemory::DatabaseMemory(String const&, std::shared_ptr) @ 0x000000002f8f427c 17. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::DatabaseMemory* std::construct_at[abi:ne190107], DB::DatabaseMemory*>(DB::DatabaseMemory*, char const* const&, std::shared_ptr&&) @ 0x0000000031b33d44 18. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:ne190107], char const* const&, std::shared_ptr, 0>(std::allocator const&, char const* const&, std::shared_ptr&&) @ 0x0000000031b339ef 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::DatabaseCatalog::initializeAndLoadTemporaryDatabase() @ 0x0000000031ad2360 20. ./build_docker/./programs/local/LocalServer.cpp:842: DB::LocalServer::processConfig() @ 0x000000002001928f 21. ./build_docker/./programs/local/LocalServer.cpp:579: DB::LocalServer::main(std::vector> const&) @ 0x000000002000bfb2 22. ./build_docker/./programs/local/LocalServer.cpp:0: non-virtual thunk to DB::LocalServer::main(std::vector> const&) @ 0x000000002000deef 23. ./build_docker/./base/poco/Util/src/Application.cpp:315: Poco::Util::Application::run() @ 0x00000000415d43df 24. ./build_docker/./programs/local/LocalServer.cpp:1071: mainEntryClickHouseLocal(int, char**) @ 0x000000002002dd60 25. ./build_docker/./programs/main.cpp:295: main @ 0x0000000008bffe77 26. ? @ 0x00007f7bf838cd90 27. ? @ 0x00007f7bf838ce40 28. _start @ 0x0000000008b7202e (version 25.3.8.10072.altinitytest (altinity build))